2025.03.05 23:47:35.055316 [ 391 ] {} Context: Server was built in debug mode. It will work slowly. 2025.03.05 23:47:35.087064 [ 391 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.03.05 23:47:35.089811 [ 391 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.03.05 23:47:35.089980 [ 391 ] {} Application: Integrity check of the executable skipped because the reference checksum could not be read. 2025.03.05 23:47:35.975708 [ 391 ] {} CloudPlacementInfo: Placement info has not been loaded 2025.03.05 23:47:36.379820 [ 391 ] {} KeeperLogStore: No logs exists in /var/lib/clickhouse/coordination/logs. It's Ok if it's the first run of clickhouse-keeper. 2025.03.05 23:47:36.380866 [ 391 ] {} KeeperLogStore: Removing all changelogs 2025.03.05 23:47:36.382296 [ 391 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.03.05 23:47:36.388022 [ 391 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.03.05 23:47:36.388132 [ 391 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.03.05 23:47:36.439655 [ 980 ] {} RaftInstance: Election timeout, initiate leader election 2025.03.05 23:47:36.546371 [ 391 ] {} Access(local_directory): File /var/lib/clickhouse/access/users.list doesn't exist 2025.03.05 23:47:36.546521 [ 391 ] {} Access(local_directory): Recovering lists in directory /var/lib/clickhouse/access/ 2025.03.05 23:47:37.142124 [ 391 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.03.05 23:47:40.900603 [ 394 ] {56b36694-53d7-4fa5-87c8-522052f79ad1} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE hits_v1; to attach existing table or CREATE TABLE hits_v1 ; to create new table or ATTACH TABLE hits_v1 FROM '/path/to/data/'
; to create new table and attach data. 2025.03.05 23:47:51.822857 [ 394 ] {96df663d-2275-48da-95e7-0c99d1accb56} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE visits_v1; to attach existing table or CREATE TABLE visits_v1
; to create new table or ATTACH TABLE visits_v1 FROM '/path/to/data/'
; to create new table and attach data. 2025.03.05 23:58:28.211866 [ 1614 ] {180db6af-2f6a-4820-8f74-beeb77afceb2} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00 million, current rows: 8.88 million. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:53996) (comment: 00175_counting_resources_in_subqueries.sql) (in query: SELECT 1 = (SELECT count() FROM test.hits WHERE NOT ignore(AdvEngineID));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000019ec0f28 6. /build/src/QueryPipeline/SizeLimits.cpp:25: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec0a4c 7. /build/src/QueryPipeline/SizeLimits.cpp:65: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000019ec0d99 8. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:258: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001dd4f663 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1971: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd6139e 10. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd07a90 11. /build/src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd3251f 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001b507541 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001b50729b 14. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:2110: DB::(anonymous namespace)::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b0be708 15. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6524: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b0a170d 16. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6640: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b09f821 17. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:5542: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b0b67f8 18. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6487: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b0a12ea 19. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6640: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b09f821 20. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6901: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b0a9fc7 21. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:8173: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b09bb43 22. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::(anonymous namespace)::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001b099d74 23. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:8408: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001b099a33 24. /build/src/Analyzer/QueryTreePassManager.cpp:186: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001b08b1a6 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:142: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001b506bac 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001b5057e6 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001b508bb7 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: DB::registerInterpreterSelectQueryAnalyzer(DB::InterpreterFactory&)::$_0::operator()(DB::InterpreterFactory::Arguments const&) const @ 0x000000001b50804c 29. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001b507ffd 30. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:470: ? @ 0x000000001b507f9d 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001b507f5d 2025.03.05 23:58:28.212803 [ 1614 ] {180db6af-2f6a-4820-8f74-beeb77afceb2} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00 million, current rows: 8.88 million. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000019ec0f28 6. /build/src/QueryPipeline/SizeLimits.cpp:25: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec0a4c 7. /build/src/QueryPipeline/SizeLimits.cpp:65: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000019ec0d99 8. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:258: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001dd4f663 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1971: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd6139e 10. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd07a90 11. /build/src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd3251f 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001b507541 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001b50729b 14. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:2110: DB::(anonymous namespace)::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b0be708 15. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6524: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b0a170d 16. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6640: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b09f821 17. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:5542: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b0b67f8 18. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6487: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b0a12ea 19. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6640: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b09f821 20. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6901: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b0a9fc7 21. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:8173: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b09bb43 22. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::(anonymous namespace)::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001b099d74 23. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:8408: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001b099a33 24. /build/src/Analyzer/QueryTreePassManager.cpp:186: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001b08b1a6 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:142: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001b506bac 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001b5057e6 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001b508bb7 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: DB::registerInterpreterSelectQueryAnalyzer(DB::InterpreterFactory&)::$_0::operator()(DB::InterpreterFactory::Arguments const&) const @ 0x000000001b50804c 29. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001b507ffd 30. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:470: ? @ 0x000000001b507f9d 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001b507f5d 2025.03.05 23:58:28.396003 [ 1614 ] {fb5270fa-1bce-4994-86df-195916277d14} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00 million, current rows: 8.88 million. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:53996) (comment: 00175_counting_resources_in_subqueries.sql) (in query: SELECT 1 IN (SELECT count() FROM test.hits WHERE NOT ignore(AdvEngineID));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000019ec0f28 6. /build/src/QueryPipeline/SizeLimits.cpp:25: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec0a4c 7. /build/src/QueryPipeline/SizeLimits.cpp:65: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000019ec0d99 8. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:258: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001dd4f663 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1971: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd6139e 10. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd07a90 11. /build/src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd3251f 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001b507541 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001b50729b 14. /build/src/Interpreters/executeQuery.cpp:1195: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001bbb14d7 15. /build/src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001bbab5aa 16. /build/src/Server/TCPHandler.cpp:517: DB::TCPHandler::runImpl() @ 0x000000001d46ec60 17. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 18. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 20. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 21. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 23. ? @ 0x00007f682805dac3 24. ? @ 0x00007f68280ef850 2025.03.05 23:58:28.396898 [ 1614 ] {fb5270fa-1bce-4994-86df-195916277d14} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00 million, current rows: 8.88 million. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000019ec0f28 6. /build/src/QueryPipeline/SizeLimits.cpp:25: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec0a4c 7. /build/src/QueryPipeline/SizeLimits.cpp:65: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000019ec0d99 8. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:258: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001dd4f663 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1971: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd6139e 10. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd07a90 11. /build/src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd3251f 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001b507541 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001b50729b 14. /build/src/Interpreters/executeQuery.cpp:1195: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001bbb14d7 15. /build/src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001bbab5aa 16. /build/src/Server/TCPHandler.cpp:517: DB::TCPHandler::runImpl() @ 0x000000001d46ec60 17. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 18. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 20. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 21. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 23. ? @ 0x00007f682805dac3 24. ? @ 0x00007f68280ef850 2025.03.05 23:58:28.880303 [ 1614 ] {0300fd79-67c1-4eec-b35a-0cb316b438eb} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 15.00 million, current rows: 17.76 million: While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:53996) (comment: 00175_counting_resources_in_subqueries.sql) (in query: SELECT count() IN (SELECT count() FROM test.hits WHERE NOT ignore(AdvEngineID)) FROM test.hits WHERE NOT ignore(AdvEngineID);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000019ec0f28 6. /build/src/QueryPipeline/SizeLimits.cpp:25: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec0a4c 7. /build/src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000019e92e84 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::executeJob(DB::ExecutingGraph::Node*, DB::ReadProgressCallback*) @ 0x000000001d532c71 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:95: DB::ExecutionThreadContext::executeTask() @ 0x000000001d532720 10. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001d514ca1 11. /build/src/Processors/Executors/PipelineExecutor.cpp:239: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000001d515037 12. /build/src/Processors/Executors/PipelineExecutor.cpp:373: DB::PipelineExecutor::spawnThreads()::$_0::operator()() const @ 0x000000001d515fd8 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d515f35 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d515f15 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d515ef5 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d515ec0 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 19. /build/src/Common/ThreadPool.cpp:526: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000133d7e82 20. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133e1cc4 21. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e1c95 22. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&, std::__tuple_indices<>) @ 0x00000000133e1c79 23. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&) @ 0x00000000133e1b1d 24. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x00000000133e19e5 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e1955 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x00000000133e1935 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x00000000133e1915 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000133e18e0 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 31. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 2025.03.05 23:58:28.934004 [ 1614 ] {0300fd79-67c1-4eec-b35a-0cb316b438eb} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 15.00 million, current rows: 17.76 million: While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000019ec0f28 6. /build/src/QueryPipeline/SizeLimits.cpp:25: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec0a4c 7. /build/src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000019e92e84 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::executeJob(DB::ExecutingGraph::Node*, DB::ReadProgressCallback*) @ 0x000000001d532c71 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:95: DB::ExecutionThreadContext::executeTask() @ 0x000000001d532720 10. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001d514ca1 11. /build/src/Processors/Executors/PipelineExecutor.cpp:239: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000001d515037 12. /build/src/Processors/Executors/PipelineExecutor.cpp:373: DB::PipelineExecutor::spawnThreads()::$_0::operator()() const @ 0x000000001d515fd8 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d515f35 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d515f15 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d515ef5 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d515ec0 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 19. /build/src/Common/ThreadPool.cpp:526: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000133d7e82 20. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133e1cc4 21. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e1c95 22. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&, std::__tuple_indices<>) @ 0x00000000133e1c79 23. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&) @ 0x00000000133e1b1d 24. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x00000000133e19e5 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e1955 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x00000000133e1935 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x00000000133e1915 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000133e18e0 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 31. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 2025.03.05 23:58:29.153774 [ 1614 ] {2055a77b-fcd4-4ab1-8f46-904208349edd} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00 million, current rows: 8.88 million. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:53996) (comment: 00175_counting_resources_in_subqueries.sql) (in query: SELECT count() FROM test.hits WHERE CounterID > (SELECT count() FROM test.hits WHERE NOT ignore(AdvEngineID));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000019ec0f28 6. /build/src/QueryPipeline/SizeLimits.cpp:25: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec0a4c 7. /build/src/QueryPipeline/SizeLimits.cpp:65: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000019ec0d99 8. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:258: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001dd4f663 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1971: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd6139e 10. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd07a90 11. /build/src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd3251f 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001b507541 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001b50729b 14. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:2110: DB::(anonymous namespace)::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b0be708 15. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6524: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b0a170d 16. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6640: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b09f821 17. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:5542: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b0b67f8 18. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6487: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b0a12ea 19. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:8198: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b09be77 20. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::(anonymous namespace)::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001b099d74 21. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:8408: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001b099a33 22. /build/src/Analyzer/QueryTreePassManager.cpp:186: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001b08b1a6 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:142: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001b506bac 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001b5057e6 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001b508bb7 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: DB::registerInterpreterSelectQueryAnalyzer(DB::InterpreterFactory&)::$_0::operator()(DB::InterpreterFactory::Arguments const&) const @ 0x000000001b50804c 27. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001b507ffd 28. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:470: ? @ 0x000000001b507f9d 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001b507f5d 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b507f25 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001b42791e 2025.03.05 23:58:29.154773 [ 1614 ] {2055a77b-fcd4-4ab1-8f46-904208349edd} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00 million, current rows: 8.88 million. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000019ec0f28 6. /build/src/QueryPipeline/SizeLimits.cpp:25: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec0a4c 7. /build/src/QueryPipeline/SizeLimits.cpp:65: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000019ec0d99 8. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:258: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001dd4f663 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1971: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd6139e 10. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd07a90 11. /build/src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd3251f 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001b507541 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001b50729b 14. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:2110: DB::(anonymous namespace)::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b0be708 15. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6524: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b0a170d 16. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6640: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b09f821 17. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:5542: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b0b67f8 18. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6487: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b0a12ea 19. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:8198: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b09be77 20. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::(anonymous namespace)::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001b099d74 21. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:8408: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001b099a33 22. /build/src/Analyzer/QueryTreePassManager.cpp:186: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001b08b1a6 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:142: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001b506bac 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001b5057e6 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001b508bb7 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: DB::registerInterpreterSelectQueryAnalyzer(DB::InterpreterFactory&)::$_0::operator()(DB::InterpreterFactory::Arguments const&) const @ 0x000000001b50804c 27. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001b507ffd 28. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:470: ? @ 0x000000001b507f9d 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001b507f5d 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b507f25 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001b42791e 2025.03.05 23:58:31.058618 [ 1614 ] {8d5775b3-e790-4c20-b098-587fd6b61de8} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 10.00 million, current rows: 13.56 million: While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:53996) (comment: 00175_counting_resources_in_subqueries.sql) (in query: SELECT count() FROM test.hits WHERE CounterID < (SELECT count() FROM test.hits WHERE NOT ignore(AdvEngineID));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000019ec0f28 6. /build/src/QueryPipeline/SizeLimits.cpp:25: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec0a4c 7. /build/src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000019e92e84 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::executeJob(DB::ExecutingGraph::Node*, DB::ReadProgressCallback*) @ 0x000000001d532c71 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:95: DB::ExecutionThreadContext::executeTask() @ 0x000000001d532720 10. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001d514ca1 11. /build/src/Processors/Executors/PipelineExecutor.cpp:239: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000001d515037 12. /build/src/Processors/Executors/PipelineExecutor.cpp:373: DB::PipelineExecutor::spawnThreads()::$_0::operator()() const @ 0x000000001d515fd8 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d515f35 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d515f15 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d515ef5 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d515ec0 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 19. /build/src/Common/ThreadPool.cpp:526: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000133d7e82 20. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133e1cc4 21. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e1c95 22. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&, std::__tuple_indices<>) @ 0x00000000133e1c79 23. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&) @ 0x00000000133e1b1d 24. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x00000000133e19e5 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e1955 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x00000000133e1935 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x00000000133e1915 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000133e18e0 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 31. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 2025.03.05 23:58:31.093258 [ 1614 ] {8d5775b3-e790-4c20-b098-587fd6b61de8} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 10.00 million, current rows: 13.56 million: While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000019ec0f28 6. /build/src/QueryPipeline/SizeLimits.cpp:25: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec0a4c 7. /build/src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000019e92e84 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::executeJob(DB::ExecutingGraph::Node*, DB::ReadProgressCallback*) @ 0x000000001d532c71 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:95: DB::ExecutionThreadContext::executeTask() @ 0x000000001d532720 10. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001d514ca1 11. /build/src/Processors/Executors/PipelineExecutor.cpp:239: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000001d515037 12. /build/src/Processors/Executors/PipelineExecutor.cpp:373: DB::PipelineExecutor::spawnThreads()::$_0::operator()() const @ 0x000000001d515fd8 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d515f35 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d515f15 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d515ef5 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d515ec0 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 19. /build/src/Common/ThreadPool.cpp:526: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000133d7e82 20. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133e1cc4 21. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e1c95 22. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&, std::__tuple_indices<>) @ 0x00000000133e1c79 23. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&) @ 0x00000000133e1b1d 24. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x00000000133e19e5 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e1955 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x00000000133e1935 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x00000000133e1915 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000133e18e0 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 31. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 2025.03.06 00:11:01.848322 [ 2035 ] {47fedf5e-465a-4575-9b04-d9e98d69e723} executeQuery: Code: 307. DB::Exception: Limit for rows or bytes to read exceeded, max bytes: 572.20 MiB, current bytes: 573.41 MiB: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_BYTES) (version 24.3.12.76.altinitystable) (from [::1]:53424) (comment: 00091_prewhere_two_conditions.sql) (in query: SELECT uniq(URL) FROM test.hits WHERE toTimeZone(EventTime, 'Asia/Dubai') >= '2014-03-20 00:00:00' AND toTimeZone(EventTime, 'Asia/Dubai') < '2014-03-21 00:00:00';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000019ec1148 6. /build/src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec0c27 7. /build/src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000019e92e84 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::executeJob(DB::ExecutingGraph::Node*, DB::ReadProgressCallback*) @ 0x000000001d532c71 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:95: DB::ExecutionThreadContext::executeTask() @ 0x000000001d532720 10. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001d514ca1 11. /build/src/Processors/Executors/PipelineExecutor.cpp:239: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000001d515037 12. /build/src/Processors/Executors/PipelineExecutor.cpp:373: DB::PipelineExecutor::spawnThreads()::$_0::operator()() const @ 0x000000001d515fd8 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d515f35 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d515f15 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d515ef5 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d515ec0 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 19. /build/src/Common/ThreadPool.cpp:526: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000133d7e82 20. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133e1cc4 21. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e1c95 22. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&, std::__tuple_indices<>) @ 0x00000000133e1c79 23. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&) @ 0x00000000133e1b1d 24. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x00000000133e19e5 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e1955 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x00000000133e1935 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x00000000133e1915 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000133e18e0 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 31. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 2025.03.06 00:11:01.876436 [ 2035 ] {47fedf5e-465a-4575-9b04-d9e98d69e723} TCPHandler: Code: 307. DB::Exception: Limit for rows or bytes to read exceeded, max bytes: 572.20 MiB, current bytes: 573.41 MiB: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000019ec1148 6. /build/src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec0c27 7. /build/src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000019e92e84 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::executeJob(DB::ExecutingGraph::Node*, DB::ReadProgressCallback*) @ 0x000000001d532c71 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:95: DB::ExecutionThreadContext::executeTask() @ 0x000000001d532720 10. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001d514ca1 11. /build/src/Processors/Executors/PipelineExecutor.cpp:239: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000001d515037 12. /build/src/Processors/Executors/PipelineExecutor.cpp:373: DB::PipelineExecutor::spawnThreads()::$_0::operator()() const @ 0x000000001d515fd8 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d515f35 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d515f15 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d515ef5 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d515ec0 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 19. /build/src/Common/ThreadPool.cpp:526: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000133d7e82 20. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133e1cc4 21. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e1c95 22. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&, std::__tuple_indices<>) @ 0x00000000133e1c79 23. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&) @ 0x00000000133e1b1d 24. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x00000000133e19e5 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e1955 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x00000000133e1935 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x00000000133e1915 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000133e18e0 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 31. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 2025.03.06 00:11:02.650978 [ 2035 ] {3f908f2e-b187-4d02-ab13-8562d3545ee7} executeQuery: Code: 307. DB::Exception: Limit for rows or bytes to read exceeded, max bytes: 572.20 MiB, current bytes: 572.80 MiB: While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (TOO_MANY_BYTES) (version 24.3.12.76.altinitystable) (from [::1]:53424) (comment: 00091_prewhere_two_conditions.sql) (in query: SELECT uniq(URL) FROM test.hits WHERE toTimeZone(EventTime, 'Asia/Dubai') >= '2014-03-20 00:00:00' AND URL != '' AND toTimeZone(EventTime, 'Asia/Dubai') < '2014-03-21 00:00:00';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000019ec1148 6. /build/src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec0c27 7. /build/src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000019e92e84 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::executeJob(DB::ExecutingGraph::Node*, DB::ReadProgressCallback*) @ 0x000000001d532c71 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:95: DB::ExecutionThreadContext::executeTask() @ 0x000000001d532720 10. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001d514ca1 11. /build/src/Processors/Executors/PipelineExecutor.cpp:239: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000001d515037 12. /build/src/Processors/Executors/PipelineExecutor.cpp:373: DB::PipelineExecutor::spawnThreads()::$_0::operator()() const @ 0x000000001d515fd8 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d515f35 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d515f15 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d515ef5 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d515ec0 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 19. /build/src/Common/ThreadPool.cpp:526: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000133d7e82 20. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133e1cc4 21. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e1c95 22. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&, std::__tuple_indices<>) @ 0x00000000133e1c79 23. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&) @ 0x00000000133e1b1d 24. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x00000000133e19e5 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e1955 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x00000000133e1935 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x00000000133e1915 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000133e18e0 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 31. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 2025.03.06 00:11:02.665253 [ 2035 ] {3f908f2e-b187-4d02-ab13-8562d3545ee7} TCPHandler: Code: 307. DB::Exception: Limit for rows or bytes to read exceeded, max bytes: 572.20 MiB, current bytes: 572.80 MiB: While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000019ec1148 6. /build/src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec0c27 7. /build/src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000019e92e84 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::executeJob(DB::ExecutingGraph::Node*, DB::ReadProgressCallback*) @ 0x000000001d532c71 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:95: DB::ExecutionThreadContext::executeTask() @ 0x000000001d532720 10. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001d514ca1 11. /build/src/Processors/Executors/PipelineExecutor.cpp:239: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000001d515037 12. /build/src/Processors/Executors/PipelineExecutor.cpp:373: DB::PipelineExecutor::spawnThreads()::$_0::operator()() const @ 0x000000001d515fd8 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d515f35 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d515f15 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d515ef5 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d515ec0 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 19. /build/src/Common/ThreadPool.cpp:526: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000133d7e82 20. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133e1cc4 21. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e1c95 22. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&, std::__tuple_indices<>) @ 0x00000000133e1c79 23. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&) @ 0x00000000133e1b1d 24. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x00000000133e19e5 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e1955 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x00000000133e1935 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x00000000133e1915 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000133e18e0 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 31. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 2025.03.06 00:11:03.455789 [ 2035 ] {21bae592-8a9a-481d-93b5-1bf93aef9d5a} executeQuery: Code: 307. DB::Exception: Limit for rows or bytes to read exceeded, max bytes: 572.20 MiB, current bytes: 574.41 MiB: While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (TOO_MANY_BYTES) (version 24.3.12.76.altinitystable) (from [::1]:53424) (comment: 00091_prewhere_two_conditions.sql) (in query: SELECT uniq(URL) FROM test.hits PREWHERE toTimeZone(EventTime, 'Asia/Dubai') >= '2014-03-20 00:00:00' AND URL != '' AND toTimeZone(EventTime, 'Asia/Dubai') < '2014-03-21 00:00:00';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000019ec1148 6. /build/src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec0c27 7. /build/src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000019e92e84 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::executeJob(DB::ExecutingGraph::Node*, DB::ReadProgressCallback*) @ 0x000000001d532c71 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:95: DB::ExecutionThreadContext::executeTask() @ 0x000000001d532720 10. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001d514ca1 11. /build/src/Processors/Executors/PipelineExecutor.cpp:239: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000001d515037 12. /build/src/Processors/Executors/PipelineExecutor.cpp:373: DB::PipelineExecutor::spawnThreads()::$_0::operator()() const @ 0x000000001d515fd8 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d515f35 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d515f15 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d515ef5 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d515ec0 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 19. /build/src/Common/ThreadPool.cpp:526: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000133d7e82 20. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133e1cc4 21. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e1c95 22. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&, std::__tuple_indices<>) @ 0x00000000133e1c79 23. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&) @ 0x00000000133e1b1d 24. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x00000000133e19e5 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e1955 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x00000000133e1935 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x00000000133e1915 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000133e18e0 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 31. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 2025.03.06 00:11:03.467842 [ 2035 ] {21bae592-8a9a-481d-93b5-1bf93aef9d5a} TCPHandler: Code: 307. DB::Exception: Limit for rows or bytes to read exceeded, max bytes: 572.20 MiB, current bytes: 574.41 MiB: While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000019ec1148 6. /build/src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec0c27 7. /build/src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000019e92e84 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::executeJob(DB::ExecutingGraph::Node*, DB::ReadProgressCallback*) @ 0x000000001d532c71 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:95: DB::ExecutionThreadContext::executeTask() @ 0x000000001d532720 10. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001d514ca1 11. /build/src/Processors/Executors/PipelineExecutor.cpp:239: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000001d515037 12. /build/src/Processors/Executors/PipelineExecutor.cpp:373: DB::PipelineExecutor::spawnThreads()::$_0::operator()() const @ 0x000000001d515fd8 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d515f35 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d515f15 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d515ef5 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d515ec0 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 19. /build/src/Common/ThreadPool.cpp:526: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000133d7e82 20. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133e1cc4 21. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e1c95 22. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&, std::__tuple_indices<>) @ 0x00000000133e1c79 23. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&) @ 0x00000000133e1b1d 24. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x00000000133e19e5 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e1955 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x00000000133e1935 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x00000000133e1915 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000133e18e0 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 31. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 2025.03.06 00:11:10.700054 [ 1614 ] {413a0156-fe03-41f2-b81b-c422613dbe5d} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.094976204 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:33294) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:10.943592 [ 2031 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:46320). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000134e5d2c 6. /build/src/IO/ReadBufferFromPocoSocket.cpp:86: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x00000000134e4ea0 7. /build/src/IO/ReadBuffer.h:70: DB::ReadBuffer::next() @ 0x000000000af5da6a 8. /build/src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001d46d877 9. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 10. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 12. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 13. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 15. ? @ 0x00007f682805dac3 16. ? @ 0x00007f68280ef850 (version 24.3.12.76.altinitystable) 2025.03.06 00:11:10.943664 [ 1614 ] {413a0156-fe03-41f2-b81b-c422613dbe5d} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.094976204 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:15.269598 [ 1614 ] {cb8d7563-3e2b-43a0-8fcc-55f267dec5d5} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.127145666 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:33302) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:15.647142 [ 2031 ] {75dc0e2c-6206-444f-ac77-ae04f6c3acae} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:32916). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:32916) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000134e8348 6. /build/src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000134e75a4 7. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a929aed 8. /build/src/Server/TCPHandler.cpp:2283: DB::TCPHandler::sendEndOfStream() @ 0x000000001d47ace3 9. /build/src/Server/TCPHandler.cpp:596: DB::TCPHandler::runImpl() @ 0x000000001d46f115 10. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 11. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 13. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 14. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 16. ? @ 0x00007f682805dac3 17. ? @ 0x00007f68280ef850 2025.03.06 00:11:15.647199 [ 3757 ] {7ff42380-de0b-44f0-8666-6631694d4ffa} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:46332). (NETWORK_ERROR) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:46332) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000134e8348 6. /build/src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000134e75a4 7. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a929aed 8. /build/src/Server/TCPHandler.cpp:2283: DB::TCPHandler::sendEndOfStream() @ 0x000000001d47ace3 9. /build/src/Server/TCPHandler.cpp:596: DB::TCPHandler::runImpl() @ 0x000000001d46f115 10. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 11. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 13. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 14. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 16. ? @ 0x00007f682805dac3 17. ? @ 0x00007f68280ef850 2025.03.06 00:11:15.720776 [ 2031 ] {75dc0e2c-6206-444f-ac77-ae04f6c3acae} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:32916). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000134e8348 6. /build/src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000134e7844 7. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a929aed 8. /build/src/Server/TCPHandler.cpp:2253: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000001d485e55 9. /build/src/Server/TCPHandler.cpp:2330: DB::TCPHandler::sendLogs() @ 0x000000001d47abff 10. /build/src/Server/TCPHandler.cpp:693: DB::TCPHandler::runImpl() @ 0x000000001d4700c2 11. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 12. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 14. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 15. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 17. ? @ 0x00007f682805dac3 18. ? @ 0x00007f68280ef850 (version 24.3.12.76.altinitystable) 2025.03.06 00:11:15.720821 [ 3757 ] {7ff42380-de0b-44f0-8666-6631694d4ffa} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:46332). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000134e8348 6. /build/src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000134e7844 7. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a929aed 8. /build/src/Server/TCPHandler.cpp:2253: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000001d485e55 9. /build/src/Server/TCPHandler.cpp:2330: DB::TCPHandler::sendLogs() @ 0x000000001d47abff 10. /build/src/Server/TCPHandler.cpp:693: DB::TCPHandler::runImpl() @ 0x000000001d4700c2 11. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 12. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 14. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 15. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 17. ? @ 0x00007f682805dac3 18. ? @ 0x00007f68280ef850 (version 24.3.12.76.altinitystable) 2025.03.06 00:11:15.721252 [ 2031 ] {75dc0e2c-6206-444f-ac77-ae04f6c3acae} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:32916). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000134e8348 6. /build/src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000134e75a4 7. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a929aed 8. /build/src/Server/TCPHandler.cpp:2283: DB::TCPHandler::sendEndOfStream() @ 0x000000001d47ace3 9. /build/src/Server/TCPHandler.cpp:596: DB::TCPHandler::runImpl() @ 0x000000001d46f115 10. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 11. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 13. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 14. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 16. ? @ 0x00007f682805dac3 17. ? @ 0x00007f68280ef850 2025.03.06 00:11:15.721400 [ 3757 ] {7ff42380-de0b-44f0-8666-6631694d4ffa} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:46332). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x00000000134e8348 6. /build/src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000134e75a4 7. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a929aed 8. /build/src/Server/TCPHandler.cpp:2283: DB::TCPHandler::sendEndOfStream() @ 0x000000001d47ace3 9. /build/src/Server/TCPHandler.cpp:596: DB::TCPHandler::runImpl() @ 0x000000001d46f115 10. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 11. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 13. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 14. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 16. ? @ 0x00007f682805dac3 17. ? @ 0x00007f68280ef850 2025.03.06 00:11:15.721919 [ 2031 ] {75dc0e2c-6206-444f-ac77-ae04f6c3acae} TCPHandler: Client has gone away. 2025.03.06 00:11:15.722057 [ 3757 ] {7ff42380-de0b-44f0-8666-6631694d4ffa} TCPHandler: Client has gone away. 2025.03.06 00:11:15.977566 [ 1614 ] {cb8d7563-3e2b-43a0-8fcc-55f267dec5d5} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.127145666 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:20.850737 [ 3757 ] {b0c4ce23-6317-45ad-8e46-bcbcd0c61a00} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.005479717 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:53948) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:20.877011 [ 3759 ] {c297b774-bbc9-4bbc-91f9-703506d9824a} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.01767014 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:54006) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:21.031893 [ 3759 ] {c297b774-bbc9-4bbc-91f9-703506d9824a} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.01767014 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:21.034729 [ 3757 ] {b0c4ce23-6317-45ad-8e46-bcbcd0c61a00} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.005479717 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:21.975360 [ 2031 ] {4a75d31d-9fd9-4d41-a723-b37f26f0a8b9} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.00346171 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:35128) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513016 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 14. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 15. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 16. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 17. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 23. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 24. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 26. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 27. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 28. ? @ 0x00007f682805dac3 29. ? @ 0x00007f68280ef850 2025.03.06 00:11:21.975687 [ 1614 ] {9e03a4a2-cb06-4b9d-972c-44406d0c6740} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.395905491 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:46492) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:22.012048 [ 3759 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:54006). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000134e5d2c 6. /build/src/IO/ReadBufferFromPocoSocket.cpp:86: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x00000000134e4ea0 7. /build/src/IO/ReadBuffer.h:70: DB::ReadBuffer::next() @ 0x000000000af5da6a 8. /build/src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001d46d877 9. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 10. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 12. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 13. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 15. ? @ 0x00007f682805dac3 16. ? @ 0x00007f68280ef850 (version 24.3.12.76.altinitystable) 2025.03.06 00:11:22.012922 [ 3757 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:53948). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000134e5d2c 6. /build/src/IO/ReadBufferFromPocoSocket.cpp:86: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x00000000134e4ea0 7. /build/src/IO/ReadBuffer.h:70: DB::ReadBuffer::next() @ 0x000000000af5da6a 8. /build/src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001d46d877 9. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 10. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 12. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 13. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 15. ? @ 0x00007f682805dac3 16. ? @ 0x00007f68280ef850 (version 24.3.12.76.altinitystable) 2025.03.06 00:11:22.070122 [ 2031 ] {4a75d31d-9fd9-4d41-a723-b37f26f0a8b9} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.00346171 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513016 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 14. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 15. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 16. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 17. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 23. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 24. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 26. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 27. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 28. ? @ 0x00007f682805dac3 29. ? @ 0x00007f68280ef850 2025.03.06 00:11:22.071004 [ 2031 ] {4a75d31d-9fd9-4d41-a723-b37f26f0a8b9} TCPHandler: Client has gone away. 2025.03.06 00:11:22.650333 [ 1614 ] {9e03a4a2-cb06-4b9d-972c-44406d0c6740} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.395905491 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:27.314910 [ 3757 ] {8c7ce412-7822-4e99-ab70-2919a49eae14} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.025189303 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:58574) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:27.436698 [ 3759 ] {58ce7873-c740-4f85-b44f-1d40231917bf} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.093730318 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:49702) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:27.498342 [ 3757 ] {8c7ce412-7822-4e99-ab70-2919a49eae14} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.025189303 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:28.056920 [ 3759 ] {58ce7873-c740-4f85-b44f-1d40231917bf} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.093730318 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:28.073056 [ 1614 ] {442993f7-e559-4c08-b6a8-b4b3c33faf6d} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.842302465 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:46308) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513016 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 14. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 15. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 16. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 17. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 23. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 24. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 26. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 27. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 28. ? @ 0x00007f682805dac3 29. ? @ 0x00007f68280ef850 2025.03.06 00:11:28.085743 [ 2719 ] {12208690-93c2-49f6-90c5-ec02ab0968e5} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.250416374 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:48966) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:28.142433 [ 3759 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:49702). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000134e5d2c 6. /build/src/IO/ReadBufferFromPocoSocket.cpp:86: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x00000000134e4ea0 7. /build/src/IO/ReadBuffer.h:70: DB::ReadBuffer::next() @ 0x000000000af5da6a 8. /build/src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001d46d877 9. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 10. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 12. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 13. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 15. ? @ 0x00007f682805dac3 16. ? @ 0x00007f68280ef850 (version 24.3.12.76.altinitystable) 2025.03.06 00:11:28.143585 [ 3757 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:58574). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000134e5d2c 6. /build/src/IO/ReadBufferFromPocoSocket.cpp:86: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x00000000134e4ea0 7. /build/src/IO/ReadBuffer.h:70: DB::ReadBuffer::next() @ 0x000000000af5da6a 8. /build/src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001d46d877 9. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 10. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 12. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 13. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 15. ? @ 0x00007f682805dac3 16. ? @ 0x00007f68280ef850 (version 24.3.12.76.altinitystable) 2025.03.06 00:11:28.146516 [ 2031 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:41754). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000134e5d2c 6. /build/src/IO/ReadBufferFromPocoSocket.cpp:86: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x00000000134e4ea0 7. /build/src/IO/ReadBuffer.h:70: DB::ReadBuffer::next() @ 0x000000000af5da6a 8. /build/src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001d46d877 9. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 10. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 12. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 13. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 15. ? @ 0x00007f682805dac3 16. ? @ 0x00007f68280ef850 (version 24.3.12.76.altinitystable) 2025.03.06 00:11:28.155832 [ 1614 ] {442993f7-e559-4c08-b6a8-b4b3c33faf6d} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.842302465 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513016 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 14. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 15. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 16. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 17. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 23. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 24. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 26. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 27. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 28. ? @ 0x00007f682805dac3 29. ? @ 0x00007f68280ef850 2025.03.06 00:11:28.156610 [ 1614 ] {442993f7-e559-4c08-b6a8-b4b3c33faf6d} TCPHandler: Client has gone away. 2025.03.06 00:11:28.488817 [ 2719 ] {12208690-93c2-49f6-90c5-ec02ab0968e5} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.250416374 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:33.077769 [ 1614 ] {e1932bc4-9407-4856-975b-07beac62f9c4} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.014079579 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:52164) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:33.264512 [ 1614 ] {e1932bc4-9407-4856-975b-07beac62f9c4} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.014079579 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:34.168866 [ 3770 ] {b35bae76-d596-48a9-9acd-8c18e1a19589} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.075057374 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:49706) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513016 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 14. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 15. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 16. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 17. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 23. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 24. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 26. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 27. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 28. ? @ 0x00007f682805dac3 29. ? @ 0x00007f68280ef850 2025.03.06 00:11:34.190813 [ 3757 ] {bd0ffeba-d32c-44cc-82e1-f2f87ea248f9} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.424189291 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:48974) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:34.248644 [ 1614 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:52164). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000134e5d2c 6. /build/src/IO/ReadBufferFromPocoSocket.cpp:86: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x00000000134e4ea0 7. /build/src/IO/ReadBuffer.h:70: DB::ReadBuffer::next() @ 0x000000000af5da6a 8. /build/src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001d46d877 9. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 10. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 12. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 13. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 15. ? @ 0x00007f682805dac3 16. ? @ 0x00007f68280ef850 (version 24.3.12.76.altinitystable) 2025.03.06 00:11:34.250423 [ 2035 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:58582). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000134e5d2c 6. /build/src/IO/ReadBufferFromPocoSocket.cpp:86: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x00000000134e4ea0 7. /build/src/IO/ReadBuffer.h:70: DB::ReadBuffer::next() @ 0x000000000af5da6a 8. /build/src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001d46d877 9. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 10. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 12. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 13. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 15. ? @ 0x00007f682805dac3 16. ? @ 0x00007f68280ef850 (version 24.3.12.76.altinitystable) 2025.03.06 00:11:34.251457 [ 2719 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:46316). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000134e5d2c 6. /build/src/IO/ReadBufferFromPocoSocket.cpp:86: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x00000000134e4ea0 7. /build/src/IO/ReadBuffer.h:70: DB::ReadBuffer::next() @ 0x000000000af5da6a 8. /build/src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001d46d877 9. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 10. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 12. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 13. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 15. ? @ 0x00007f682805dac3 16. ? @ 0x00007f68280ef850 (version 24.3.12.76.altinitystable) 2025.03.06 00:11:34.252782 [ 3759 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:41764). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000134e5d2c 6. /build/src/IO/ReadBufferFromPocoSocket.cpp:86: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x00000000134e4ea0 7. /build/src/IO/ReadBuffer.h:70: DB::ReadBuffer::next() @ 0x000000000af5da6a 8. /build/src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001d46d877 9. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 10. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 12. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 13. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 15. ? @ 0x00007f682805dac3 16. ? @ 0x00007f68280ef850 (version 24.3.12.76.altinitystable) 2025.03.06 00:11:34.281245 [ 3770 ] {b35bae76-d596-48a9-9acd-8c18e1a19589} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.075057374 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513016 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 14. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 15. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 16. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 17. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 23. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 24. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 26. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 27. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 28. ? @ 0x00007f682805dac3 29. ? @ 0x00007f68280ef850 2025.03.06 00:11:34.282170 [ 3770 ] {b35bae76-d596-48a9-9acd-8c18e1a19589} TCPHandler: Client has gone away. 2025.03.06 00:11:34.764736 [ 3757 ] {bd0ffeba-d32c-44cc-82e1-f2f87ea248f9} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.424189291 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:39.671927 [ 3757 ] {9c0e921f-4172-4bb5-bee7-55dc8ed612bc} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.614123086 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:53596) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6,7}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513016 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 14. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 15. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 16. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 17. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 23. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 24. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 26. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 27. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 28. ? @ 0x00007f682805dac3 29. ? @ 0x00007f68280ef850 2025.03.06 00:11:39.762586 [ 3757 ] {9c0e921f-4172-4bb5-bee7-55dc8ed612bc} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.614123086 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513016 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 14. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 15. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 16. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 17. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 23. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 24. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 26. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 27. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 28. ? @ 0x00007f682805dac3 29. ? @ 0x00007f68280ef850 2025.03.06 00:11:45.780429 [ 3783 ] {b3bb6780-7505-492b-b4db-1a35786e6be6} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.048769101 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:53950) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513016 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 14. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 15. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 16. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 17. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 23. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 24. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 26. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 27. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 28. ? @ 0x00007f682805dac3 29. ? @ 0x00007f68280ef850 2025.03.06 00:11:45.851342 [ 3813 ] {a44c6179-01cb-43b0-91ed-2bb978fdfcfd} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.044651185 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:53484) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513016 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 14. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 15. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 16. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 17. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 23. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 24. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 26. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 27. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 28. ? @ 0x00007f682805dac3 29. ? @ 0x00007f68280ef850 2025.03.06 00:11:45.854950 [ 3759 ] {335dd365-a947-49b6-a163-f477a95612de} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.529692366 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:53626) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6,7,8}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:45.855057 [ 3783 ] {b3bb6780-7505-492b-b4db-1a35786e6be6} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.048769101 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513016 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 14. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 15. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 16. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 17. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 23. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 24. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 26. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 27. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 28. ? @ 0x00007f682805dac3 29. ? @ 0x00007f68280ef850 2025.03.06 00:11:45.891303 [ 3783 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:53950). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000134e5d2c 6. /build/src/IO/ReadBufferFromPocoSocket.cpp:86: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x00000000134e4ea0 7. /build/src/IO/ReadBuffer.h:70: DB::ReadBuffer::next() @ 0x000000000af5da6a 8. /build/src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001d46d877 9. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 10. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 12. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 13. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 15. ? @ 0x00007f682805dac3 16. ? @ 0x00007f68280ef850 (version 24.3.12.76.altinitystable) 2025.03.06 00:11:45.892466 [ 3770 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:52330). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000134e5d2c 6. /build/src/IO/ReadBufferFromPocoSocket.cpp:86: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x00000000134e4ea0 7. /build/src/IO/ReadBuffer.h:70: DB::ReadBuffer::next() @ 0x000000000af5da6a 8. /build/src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001d46d877 9. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 10. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 12. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 13. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 15. ? @ 0x00007f682805dac3 16. ? @ 0x00007f68280ef850 (version 24.3.12.76.altinitystable) 2025.03.06 00:11:45.893331 [ 1614 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:36884). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000134e5d2c 6. /build/src/IO/ReadBufferFromPocoSocket.cpp:86: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x00000000134e4ea0 7. /build/src/IO/ReadBuffer.h:70: DB::ReadBuffer::next() @ 0x000000000af5da6a 8. /build/src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001d46d877 9. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 10. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 12. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 13. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 15. ? @ 0x00007f682805dac3 16. ? @ 0x00007f68280ef850 (version 24.3.12.76.altinitystable) 2025.03.06 00:11:45.894181 [ 2035 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:45978). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000134e5d2c 6. /build/src/IO/ReadBufferFromPocoSocket.cpp:86: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x00000000134e4ea0 7. /build/src/IO/ReadBuffer.h:70: DB::ReadBuffer::next() @ 0x000000000af5da6a 8. /build/src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001d46d877 9. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 10. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 12. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 13. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 15. ? @ 0x00007f682805dac3 16. ? @ 0x00007f68280ef850 (version 24.3.12.76.altinitystable) 2025.03.06 00:11:45.895194 [ 2719 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:38734). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000134e5d2c 6. /build/src/IO/ReadBufferFromPocoSocket.cpp:86: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x00000000134e4ea0 7. /build/src/IO/ReadBuffer.h:70: DB::ReadBuffer::next() @ 0x000000000af5da6a 8. /build/src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001d46d877 9. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 10. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 12. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 13. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 15. ? @ 0x00007f682805dac3 16. ? @ 0x00007f68280ef850 (version 24.3.12.76.altinitystable) 2025.03.06 00:11:45.895848 [ 2031 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:60112). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000134e5d2c 6. /build/src/IO/ReadBufferFromPocoSocket.cpp:86: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x00000000134e4ea0 7. /build/src/IO/ReadBuffer.h:70: DB::ReadBuffer::next() @ 0x000000000af5da6a 8. /build/src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001d46d877 9. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 10. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 12. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 13. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 15. ? @ 0x00007f682805dac3 16. ? @ 0x00007f68280ef850 (version 24.3.12.76.altinitystable) 2025.03.06 00:11:45.929046 [ 3813 ] {a44c6179-01cb-43b0-91ed-2bb978fdfcfd} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.044651185 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513016 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 14. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 15. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 16. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 17. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 23. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 24. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 26. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 27. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 28. ? @ 0x00007f682805dac3 29. ? @ 0x00007f68280ef850 2025.03.06 00:11:45.929760 [ 3813 ] {a44c6179-01cb-43b0-91ed-2bb978fdfcfd} TCPHandler: Client has gone away. 2025.03.06 00:11:46.243852 [ 3759 ] {335dd365-a947-49b6-a163-f477a95612de} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.529692366 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:51.055012 [ 1614 ] {a3fe4219-160e-4cc4-8b94-9bb463e5c57c} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.167979273 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:35136) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:51.055889 [ 2719 ] {310bb97b-6a24-458f-83e0-1d5a560dbd37} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.068695906 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:44250) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:51.064795 [ 3817 ] {b1ca3703-c5a6-402f-b32d-12f5b6d0a794} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.0608491 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:51246) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:51.105912 [ 3816 ] {73190528-bf3a-4dc1-bcc7-4efb3744accf} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.009690532 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:33358) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:51.246098 [ 3817 ] {b1ca3703-c5a6-402f-b32d-12f5b6d0a794} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.0608491 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:51.294147 [ 1614 ] {a3fe4219-160e-4cc4-8b94-9bb463e5c57c} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.167979273 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:51.747861 [ 3816 ] {73190528-bf3a-4dc1-bcc7-4efb3744accf} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.009690532 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:51.865947 [ 2719 ] {310bb97b-6a24-458f-83e0-1d5a560dbd37} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.068695906 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:52.153389 [ 3770 ] {3fa66007-095b-4e5e-9770-b2c9a138d46c} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.211320158 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:48060) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513016 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 14. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 15. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 16. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 17. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 23. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 24. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 26. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 27. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 28. ? @ 0x00007f682805dac3 29. ? @ 0x00007f68280ef850 2025.03.06 00:11:52.180856 [ 3813 ] {2261d48e-da23-48df-a97d-7668113635a8} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.24785898 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:52294) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513016 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 14. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 15. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 16. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 17. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 23. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 24. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 26. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 27. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 28. ? @ 0x00007f682805dac3 29. ? @ 0x00007f68280ef850 2025.03.06 00:11:52.200047 [ 2035 ] {abd4481f-509e-4fb4-b1f0-d71dfab54515} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.332787877 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:46422) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513016 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 14. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 15. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 16. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 17. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 23. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 24. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 26. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 27. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 28. ? @ 0x00007f682805dac3 29. ? @ 0x00007f68280ef850 2025.03.06 00:11:52.228146 [ 3759 ] {c16d6c8a-a64e-46c2-ab69-163414f19b97} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.774677153 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:41966) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6,7,8,9}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:52.247606 [ 3783 ] {e6304970-8b28-4d4c-96c2-610450f7328d} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.17974701 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::ffff:127.0.0.1]:55680) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513016 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 14. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 15. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 16. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 17. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 23. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 24. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 26. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 27. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 28. ? @ 0x00007f682805dac3 29. ? @ 0x00007f68280ef850 2025.03.06 00:11:52.265333 [ 3770 ] {3fa66007-095b-4e5e-9770-b2c9a138d46c} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.211320158 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513016 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 14. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 15. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 16. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 17. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 23. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 24. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 26. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 27. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 28. ? @ 0x00007f682805dac3 29. ? @ 0x00007f68280ef850 2025.03.06 00:11:52.275591 [ 3817 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:51246). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000134e5d2c 6. /build/src/IO/ReadBufferFromPocoSocket.cpp:86: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x00000000134e4ea0 7. /build/src/IO/ReadBuffer.h:70: DB::ReadBuffer::next() @ 0x000000000af5da6a 8. /build/src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001d46d877 9. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 10. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 12. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 13. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 15. ? @ 0x00007f682805dac3 16. ? @ 0x00007f68280ef850 (version 24.3.12.76.altinitystable) 2025.03.06 00:11:52.277128 [ 3813 ] {2261d48e-da23-48df-a97d-7668113635a8} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.24785898 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513016 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 14. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 15. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 16. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 17. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 23. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 24. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 26. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 27. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 28. ? @ 0x00007f682805dac3 29. ? @ 0x00007f68280ef850 2025.03.06 00:11:52.279938 [ 3813 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:52294). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000134e5d2c 6. /build/src/IO/ReadBufferFromPocoSocket.cpp:86: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x00000000134e4ea0 7. /build/src/IO/ReadBuffer.h:70: DB::ReadBuffer::next() @ 0x000000000af5da6a 8. /build/src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001d46d877 9. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 10. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 12. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 13. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 15. ? @ 0x00007f682805dac3 16. ? @ 0x00007f68280ef850 (version 24.3.12.76.altinitystable) 2025.03.06 00:11:52.282867 [ 3770 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:48060). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000134e5d2c 6. /build/src/IO/ReadBufferFromPocoSocket.cpp:86: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x00000000134e4ea0 7. /build/src/IO/ReadBuffer.h:70: DB::ReadBuffer::next() @ 0x000000000af5da6a 8. /build/src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001d46d877 9. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 10. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 12. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 13. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 15. ? @ 0x00007f682805dac3 16. ? @ 0x00007f68280ef850 (version 24.3.12.76.altinitystable) 2025.03.06 00:11:52.284897 [ 1614 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket ([::ffff:127.0.0.1]:35136). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/NetException.h:26: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x00000000134e5d2c 6. /build/src/IO/ReadBufferFromPocoSocket.cpp:86: DB::ReadBufferFromPocoSocket::nextImpl() @ 0x00000000134e4ea0 7. /build/src/IO/ReadBuffer.h:70: DB::ReadBuffer::next() @ 0x000000000af5da6a 8. /build/src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001d46d877 9. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d485ec5 10. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228abcd9 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228ac528 12. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a83854 13. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a805fa 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a7f33e 15. ? @ 0x00007f682805dac3 16. ? @ 0x00007f68280ef850 (version 24.3.12.76.altinitystable) 2025.03.06 00:11:52.289060 [ 2035 ] {abd4481f-509e-4fb4-b1f0-d71dfab54515} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.332787877 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513016 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 14. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 15. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 16. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 17. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 23. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 24. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 26. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 27. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 28. ? @ 0x00007f682805dac3 29. ? @ 0x00007f68280ef850 2025.03.06 00:11:52.289733 [ 2035 ] {abd4481f-509e-4fb4-b1f0-d71dfab54515} TCPHandler: Client has gone away. 2025.03.06 00:11:52.337961 [ 3783 ] {e6304970-8b28-4d4c-96c2-610450f7328d} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.17974701 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513016 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 14. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 15. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 16. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 17. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 23. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 24. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 26. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 27. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 28. ? @ 0x00007f682805dac3 29. ? @ 0x00007f68280ef850 2025.03.06 00:11:52.338752 [ 3783 ] {e6304970-8b28-4d4c-96c2-610450f7328d} TCPHandler: Client has gone away. 2025.03.06 00:11:52.581471 [ 3759 ] {c16d6c8a-a64e-46c2-ab69-163414f19b97} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.774677153 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51427f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513b3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 29. ? @ 0x00007f682805dac3 30. ? @ 0x00007f68280ef850 2025.03.06 00:11:57.280359 [ 3783 ] {bdd58b14-2a62-4156-8f89-608350250517} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.44373272 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:48144) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6,7,8,9,10}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513016 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 14. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 15. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 16. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 17. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 23. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 24. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 26. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 27. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 28. ? @ 0x00007f682805dac3 29. ? @ 0x00007f68280ef850 2025.03.06 00:11:57.382212 [ 3783 ] {bdd58b14-2a62-4156-8f89-608350250517} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.44373272 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f8182 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f814d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a03aa0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132ba32e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eed2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e955cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e949d9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e948e8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a525e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d513bc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d513016 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d538b70 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d5389df 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538955 14. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d538939 15. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d53889d 16. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5387a7 17. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d538715 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5386f5 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5386d5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5386a0 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b42fb6 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b42bf5 23. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d46b1 24. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dc104 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dc0b5 26. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dc07d 27. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dbe82 28. ? @ 0x00007f682805dac3 29. ? @ 0x00007f68280ef850 2025.03.06 00:22:29.238644 [ 391 ] {} Application: Closed all listening sockets. Waiting for 4 outstanding connections. 2025.03.06 00:22:34.145158 [ 391 ] {} Application: Closed connections. But 4 remain. Tip: To increase wait time add to config: 60 2025.03.06 00:22:34.145361 [ 391 ] {} Application: Will shutdown forcefully.