2025.09.06 08:24:33.152670 [ 353 ] {} Context: Server was built with thread sanitizer. It will work slowly. 2025.09.06 08:24:33.195479 [ 353 ] {} 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.09.06 08:24:33.196689 [ 353 ] {} 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.09.06 08:24:34.579840 [ 353 ] {} KeeperLogStore: No logs exists in /var/lib/clickhouse/coordination/logs. It's Ok if it's the first run of clickhouse-keeper. 2025.09.06 08:24:34.581095 [ 353 ] {} KeeperLogStore: Removing all changelogs 2025.09.06 08:24:34.582394 [ 353 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.09.06 08:24:34.593123 [ 353 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.09.06 08:24:34.593176 [ 353 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.09.06 08:24:34.644634 [ 962 ] {} RaftInstance: Election timeout, initiate leader election 2025.09.06 08:24:34.687067 [ 353 ] {} Access(local_directory): File /var/lib/clickhouse/access/users.list doesn't exist 2025.09.06 08:24:34.687135 [ 353 ] {} Access(local_directory): Recovering lists in directory /var/lib/clickhouse/access/ 2025.09.06 08:24:34.891717 [ 353 ] {} 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.09.06 08:24:36.301723 [ 363 ] {ab27921e-3ad9-469f-83c1-5b854a51469a} 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.09.06 08:24:46.894945 [ 363 ] {1877e431-46d5-4a4c-88d8-ef2b9910d3ea} 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.09.06 08:32:31.266512 [ 1636 ] {6a4bec84-c518-49f7-bac8-a158ed81407c} executeQuery: Code: 210. DB::Exception: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:60354): While executing CSVRowOutputFormat. (NETWORK_ERROR) (version 24.8.14.10512.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:60354) (comment: 00159_parallel_formatting_http.sh) (in query: SELECT ClientEventTime::DateTime('Asia/Dubai') as a,MobilePhoneModel as b,ClientIP6 as c FROM test.hits ORDER BY a,b,c LIMIT 1000000 Format CSV ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe46b0 4. ./src/Server/HTTP/HTTPServerResponse.h:165: DB::HTTPWriteBuffer::nextImplChunked() @ 0x000000001a21501e 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:126: DB::WriteBufferFromHTTPServerResponse::nextImpl() @ 0x000000001a2142dc 6. ./src/IO/WriteBuffer.h:66: DB::IOutputFormat::flush() @ 0x000000001a30341d 7. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:106: DB::IOutputFormat::work() @ 0x000000001a3031f7 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f1c0a 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e3183 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e4293 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb19408 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20de6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb20d02 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007fc4ea2adac3 18. ? @ 0x00007fc4ea33f850 2025.09.06 08:32:36.012422 [ 1636 ] {6a4bec84-c518-49f7-bac8-a158ed81407c} DynamicQueryHandler: Code: 210. DB::Exception: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:60354): While executing CSVRowOutputFormat. (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe46b0 4. ./src/Server/HTTP/HTTPServerResponse.h:165: DB::HTTPWriteBuffer::nextImplChunked() @ 0x000000001a21501e 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:126: DB::WriteBufferFromHTTPServerResponse::nextImpl() @ 0x000000001a2142dc 6. ./src/IO/WriteBuffer.h:66: DB::IOutputFormat::flush() @ 0x000000001a30341d 7. ./build_docker/./src/Processors/Formats/IOutputFormat.cpp:106: DB::IOutputFormat::work() @ 0x000000001a3031f7 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f1c0a 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e3183 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e4293 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb19408 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20de6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb20d02 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 16. __tsan_thread_start_func @ 0x000000000758af2f 17. ? @ 0x00007fc4ea2adac3 18. ? @ 0x00007fc4ea33f850 (version 24.8.14.10512.altinitytest (altinity build)) 2025.09.06 08:32:36.207356 [ 1636 ] {6a4bec84-c518-49f7-bac8-a158ed81407c} DynamicQueryHandler: Cannot send exception to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:60354). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x000000000fbe3bcf 4. ./src/Server/HTTP/HTTPServerResponse.h:164: DB::HTTPWriteBuffer::nextImplChunked() @ 0x000000001a215016 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:126: DB::WriteBufferFromHTTPServerResponse::nextImpl() @ 0x000000001a2142dc 6. ./src/IO/WriteBuffer.h:66: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x000000001a132944 7. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a135b1c 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a20c9db 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 (version 24.8.14.10512.altinitytest (altinity build)) 2025.09.06 08:34:17.404233 [ 2205 ] {d1abe08d-00ef-498f-aa81-b3a57faa48ad} 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.8.14.10512.altinitytest (altinity build)) (from [::1]:46678) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000016e32d0c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e329a3 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e32c7d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93e129 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e3b62 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90ecf9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dbaf29 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017dbabd0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:537: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174a4a3b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001749aebe 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749973b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174b5f28 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001749a9e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749973b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cc7c5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174923f4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000174912a7 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017490705 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c875a7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dba230 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db6f20 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dbb570 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3938e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216ee7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000182131f8 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d9cdc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 2025.09.06 08:34:17.405328 [ 2205 ] {d1abe08d-00ef-498f-aa81-b3a57faa48ad} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000016e32d0c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e329a3 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e32c7d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93e129 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e3b62 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90ecf9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dbaf29 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017dbabd0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:537: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174a4a3b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001749aebe 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749973b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174b5f28 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001749a9e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749973b 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174cc7c5 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174923f4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000174912a7 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017490705 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c875a7 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dba230 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db6f20 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dbb570 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3938e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216ee7 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000182131f8 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d9cdc 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 2025.09.06 08:34:17.524280 [ 2205 ] {a1a6ac82-7829-4194-a2fb-a29f47d8538d} 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.8.14.10512.altinitytest (altinity build)) (from [::1]:46678) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000016e32d0c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e329a3 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e32c7d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93e129 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e3b62 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90ecf9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dbaf29 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017dbabd0 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018217cc7 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000182131f8 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d9cdc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007fc4ea2adac3 22. ? @ 0x00007fc4ea33f850 2025.09.06 08:34:17.525340 [ 2205 ] {a1a6ac82-7829-4194-a2fb-a29f47d8538d} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000016e32d0c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e329a3 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e32c7d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93e129 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e3b62 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90ecf9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dbaf29 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017dbabd0 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018217cc7 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000182131f8 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d9cdc 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 20. __tsan_thread_start_func @ 0x000000000758af2f 21. ? @ 0x00007fc4ea2adac3 22. ? @ 0x00007fc4ea33f850 2025.09.06 08:34:17.694987 [ 2205 ] {3202c27b-41b2-4c3a-a35c-99cc760bfc53} 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.8.14.10512.altinitytest (altinity build)) (from [::1]:46678) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000016e32d0c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e329a3 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000016dfc543 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f1cbd 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e3183 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e4293 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb19408 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20de6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb20d02 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:34:17.698379 [ 2205 ] {3202c27b-41b2-4c3a-a35c-99cc760bfc53} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000016e32d0c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e329a3 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000016dfc543 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f1cbd 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e3183 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e4293 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb19408 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20de6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb20d02 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:34:17.880542 [ 2205 ] {7ff95e82-3156-4049-b842-cee9b1a01815} 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.8.14.10512.altinitytest (altinity build)) (from [::1]:46678) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000016e32d0c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e329a3 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e32c7d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93e129 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e3b62 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90ecf9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dbaf29 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017dbabd0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:537: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174a4a3b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001749aebe 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749973b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174b5f28 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001749a9e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174926a9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000174912a7 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017490705 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c875a7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dba230 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db6f20 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dbb570 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3938e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216ee7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000182131f8 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d9cdc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 2025.09.06 08:34:17.881357 [ 2205 ] {7ff95e82-3156-4049-b842-cee9b1a01815} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000016e32d0c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e329a3 5. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:64: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000016e32c7d 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:263: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a93e129 7. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8e3b62 8. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a90ecf9 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dbaf29 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017dbabd0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:537: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174a4a3b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001749aebe 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000001749973b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174b5f28 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001749a9e6 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174926a9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000174912a7 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017490705 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c875a7 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dba230 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017db6f20 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dbb570 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d3938e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018216ee7 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x00000000182131f8 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1d9cdc 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 2025.09.06 08:34:17.995665 [ 2205 ] {da1880d1-aaf1-4685-a32a-478f60f66452} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 10.00 million, current rows: 13.12 million: While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (TOO_MANY_ROWS) (version 24.8.14.10512.altinitytest (altinity build)) (from [::1]:46678) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000016e32d0c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e329a3 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000016dfc543 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f1cbd 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e3183 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e4293 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb19408 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20de6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb20d02 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:34:18.015955 [ 2205 ] {da1880d1-aaf1-4685-a32a-478f60f66452} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 10.00 million, current rows: 13.12 million: While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000016e32d0c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:0: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e329a3 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000016dfc543 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f1cbd 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e3183 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e4293 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb19408 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20de6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb20d02 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:34:33.607629 [ 1636 ] {b30f26b0-94ee-4c02-904d-d3ead8c47c85} executeQuery: Code: 307. DB::Exception: Limit for rows or bytes to read exceeded, max bytes: 572.20 MiB, current bytes: 572.35 MiB: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_BYTES) (version 24.8.14.10512.altinitytest (altinity build)) (from [::1]:60060) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000016e32e4c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e32ad0 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000016dfc543 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f1cbd 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e3183 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e4293 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb19408 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20de6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb20d02 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:34:33.620885 [ 1636 ] {b30f26b0-94ee-4c02-904d-d3ead8c47c85} TCPHandler: Code: 307. DB::Exception: Limit for rows or bytes to read exceeded, max bytes: 572.20 MiB, current bytes: 572.35 MiB: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000016e32e4c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e32ad0 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000016dfc543 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f1cbd 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e3183 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e4293 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb19408 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20de6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb20d02 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:34:43.343239 [ 1636 ] {51284411-c8ec-4445-b3d1-e615c82b4d07} executeQuery: Code: 307. DB::Exception: Limit for rows or bytes to read exceeded, max bytes: 572.20 MiB, current bytes: 572.48 MiB: While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (TOO_MANY_BYTES) (version 24.8.14.10512.altinitytest (altinity build)) (from [::1]:60060) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000016e32e4c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e32ad0 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000016dfc543 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f1cbd 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e3183 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e4293 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb19408 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20de6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb20d02 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:34:43.352395 [ 1636 ] {51284411-c8ec-4445-b3d1-e615c82b4d07} TCPHandler: Code: 307. DB::Exception: Limit for rows or bytes to read exceeded, max bytes: 572.20 MiB, current bytes: 572.48 MiB: While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000016e32e4c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e32ad0 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000016dfc543 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f1cbd 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e3183 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e4293 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb19408 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20de6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb20d02 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:34:51.203317 [ 1636 ] {50a53ed3-d9e4-4290-8840-e2c5b5fc3d74} executeQuery: Code: 307. DB::Exception: Limit for rows or bytes to read exceeded, max bytes: 572.20 MiB, current bytes: 572.37 MiB: While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (TOO_MANY_BYTES) (version 24.8.14.10512.altinitytest (altinity build)) (from [::1]:60060) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000016e32e4c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e32ad0 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000016dfc543 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f1cbd 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e3183 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e4293 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb19408 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20de6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb20d02 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:34:51.210459 [ 1636 ] {50a53ed3-d9e4-4290-8840-e2c5b5fc3d74} TCPHandler: Code: 307. DB::Exception: Limit for rows or bytes to read exceeded, max bytes: 572.20 MiB, current bytes: 572.37 MiB: While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000016e32e4c 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:35: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000016e32ad0 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000016dfc543 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000001a2f1cbd 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2e3183 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2e4293 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb19408 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb20de6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb20d02 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:50.894808 [ 2909 ] {4c17a4b3-f753-48c7-bb5c-bee25960a15f} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.041126621 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10512.altinitytest (altinity build)) (from [::1]:53600) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016dfe206 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016dfd326 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x0000000017edfa01 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2e2888 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e24c8 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f683b 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 11. __tsan_thread_start_func @ 0x000000000758af2f 12. ? @ 0x00007fc4ea2adac3 13. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:50.913113 [ 2909 ] {4c17a4b3-f753-48c7-bb5c-bee25960a15f} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.041126621 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016dfe206 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016dfd326 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x0000000017edfa01 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2e2888 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e24c8 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f683b 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 11. __tsan_thread_start_func @ 0x000000000758af2f 12. ? @ 0x00007fc4ea2adac3 13. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:50.984394 [ 4084 ] {14c5b66a-64c0-42db-a372-57d28ec3f3b4} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:55390). (NETWORK_ERROR) (version 24.8.14.10512.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:55390) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe44f2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000001a1e8da5 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1da082 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007fc4ea2adac3 15. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:51.058307 [ 4084 ] {14c5b66a-64c0-42db-a372-57d28ec3f3b4} 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]:55390). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe46b0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000001a1f93c7 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000001a1e89bc 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1da219 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 (version 24.8.14.10512.altinitytest (altinity build)) 2025.09.06 08:47:51.058650 [ 4084 ] {14c5b66a-64c0-42db-a372-57d28ec3f3b4} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:55390). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe44f2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000001a1e8da5 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1da082 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 13. __tsan_thread_start_func @ 0x000000000758af2f 14. ? @ 0x00007fc4ea2adac3 15. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:51.059208 [ 4084 ] {14c5b66a-64c0-42db-a372-57d28ec3f3b4} TCPHandler: Client has gone away. 2025.09.06 08:47:52.338273 [ 4084 ] {58930091-9fcc-4e45-b5a2-e133af22ea9a} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.074598403 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10512.altinitytest (altinity build)) (from [::1]:50116) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016dfe206 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016dfd326 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x0000000017edfa01 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2e2888 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e24c8 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f683b 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 11. __tsan_thread_start_func @ 0x000000000758af2f 12. ? @ 0x00007fc4ea2adac3 13. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:52.388189 [ 4084 ] {58930091-9fcc-4e45-b5a2-e133af22ea9a} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.074598403 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016dfe206 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016dfd326 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x0000000017edfa01 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2e2888 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e24c8 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f683b 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 11. __tsan_thread_start_func @ 0x000000000758af2f 12. ? @ 0x00007fc4ea2adac3 13. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:52.503084 [ 4158 ] {e090cb45-3fbc-45bd-944d-69e740cbc092} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:52040). (NETWORK_ERROR) (version 24.8.14.10512.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:52040) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe46b0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProgress() @ 0x000000001a1e7e89 6. ./build_docker/./src/Server/TCPHandler.cpp:1170: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e7ab3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9e7f 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:52.510378 [ 2909 ] {e92c3ebe-29b1-48ab-a598-c60e7756734f} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:57074). (NETWORK_ERROR) (version 24.8.14.10512.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57074) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe44f2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000001a1ea71d 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e774c 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9e7f 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:52.513210 [ 4158 ] {e090cb45-3fbc-45bd-944d-69e740cbc092} 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]:52040). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe46b0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000001a1f93c7 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000001a1e89bc 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1da219 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 (version 24.8.14.10512.altinitytest (altinity build)) 2025.09.06 08:47:52.513411 [ 4158 ] {e090cb45-3fbc-45bd-944d-69e740cbc092} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:52040). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe46b0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProgress() @ 0x000000001a1e7e89 6. ./build_docker/./src/Server/TCPHandler.cpp:1170: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e7ab3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9e7f 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:52.513867 [ 4158 ] {e090cb45-3fbc-45bd-944d-69e740cbc092} TCPHandler: Client has gone away. 2025.09.06 08:47:52.521568 [ 2909 ] {e92c3ebe-29b1-48ab-a598-c60e7756734f} 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]:57074). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe46b0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000001a1f93c7 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000001a1e89bc 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1da219 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 (version 24.8.14.10512.altinitytest (altinity build)) 2025.09.06 08:47:52.521794 [ 2909 ] {e92c3ebe-29b1-48ab-a598-c60e7756734f} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:57074). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe44f2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000001a1ea71d 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e774c 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9e7f 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:52.522162 [ 2909 ] {e92c3ebe-29b1-48ab-a598-c60e7756734f} TCPHandler: Client has gone away. 2025.09.06 08:47:53.801757 [ 4084 ] {e983d709-1eff-4c7c-88c7-610605c286c8} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.047853714 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10512.altinitytest (altinity build)) (from [::1]:50124) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016dfe206 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016dfd326 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x0000000017edfa01 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2e2888 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e24c8 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f683b 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 11. __tsan_thread_start_func @ 0x000000000758af2f 12. ? @ 0x00007fc4ea2adac3 13. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:53.845388 [ 4084 ] {e983d709-1eff-4c7c-88c7-610605c286c8} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.047853714 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016dfe206 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016dfd326 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x0000000017edfa01 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2e2888 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e24c8 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f683b 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 11. __tsan_thread_start_func @ 0x000000000758af2f 12. ? @ 0x00007fc4ea2adac3 13. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:53.872905 [ 4158 ] {ac5a9936-2e01-423d-b556-e0b31dfbf410} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:45338). (NETWORK_ERROR) (version 24.8.14.10512.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:45338) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe46b0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProgress() @ 0x000000001a1e7e89 6. ./build_docker/./src/Server/TCPHandler.cpp:1170: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e7ab3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9e7f 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:53.880060 [ 2909 ] {35a850b0-223f-4b5c-8839-f834f8257056} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:57084). (NETWORK_ERROR) (version 24.8.14.10512.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57084) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe44f2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000001a1ea71d 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e774c 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9e7f 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:53.891062 [ 4158 ] {ac5a9936-2e01-423d-b556-e0b31dfbf410} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:45338). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe46b0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000001a1f93c7 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000001a1e89bc 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1da219 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 (version 24.8.14.10512.altinitytest (altinity build)) 2025.09.06 08:47:53.891512 [ 4158 ] {ac5a9936-2e01-423d-b556-e0b31dfbf410} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:45338). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe46b0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProgress() @ 0x000000001a1e7e89 6. ./build_docker/./src/Server/TCPHandler.cpp:1170: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e7ab3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9e7f 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:53.892351 [ 4158 ] {ac5a9936-2e01-423d-b556-e0b31dfbf410} TCPHandler: Client has gone away. 2025.09.06 08:47:53.902615 [ 2909 ] {35a850b0-223f-4b5c-8839-f834f8257056} 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]:57084). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe46b0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000001a1f93c7 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000001a1e89bc 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1da219 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 (version 24.8.14.10512.altinitytest (altinity build)) 2025.09.06 08:47:53.903035 [ 2909 ] {35a850b0-223f-4b5c-8839-f834f8257056} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:57084). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe44f2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000001a1ea71d 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e774c 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9e7f 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:53.903785 [ 2909 ] {35a850b0-223f-4b5c-8839-f834f8257056} TCPHandler: Client has gone away. 2025.09.06 08:47:53.908125 [ 4162 ] {5198a786-7d96-4248-a358-0baad8c73788} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:52054). (NETWORK_ERROR) (version 24.8.14.10512.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:52054) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe44f2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000001a1ea71d 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e774c 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9e7f 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:53.919890 [ 4162 ] {5198a786-7d96-4248-a358-0baad8c73788} 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]:52054). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe46b0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000001a1f93c7 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000001a1e89bc 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1da219 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 (version 24.8.14.10512.altinitytest (altinity build)) 2025.09.06 08:47:53.920110 [ 4162 ] {5198a786-7d96-4248-a358-0baad8c73788} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:52054). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe44f2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000001a1ea71d 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e774c 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9e7f 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:53.920644 [ 4162 ] {5198a786-7d96-4248-a358-0baad8c73788} TCPHandler: Client has gone away. 2025.09.06 08:47:55.294061 [ 4084 ] {ff62fadb-9200-4dc7-8733-981cde90b515} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.079619854 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10512.altinitytest (altinity build)) (from [::1]:50126) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016dfe206 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016dfd326 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x0000000017edfa01 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2e2888 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e24c8 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f683b 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 11. __tsan_thread_start_func @ 0x000000000758af2f 12. ? @ 0x00007fc4ea2adac3 13. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:55.325691 [ 4162 ] {e0d22f6c-1002-4383-8314-f7ce935dbcec} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:57092). (NETWORK_ERROR) (version 24.8.14.10512.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57092) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe44f2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000001a1ea71d 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e774c 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9e7f 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:55.343861 [ 4166 ] {82a823aa-3093-4165-b7eb-fbfaaf4d8503} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:45340). (NETWORK_ERROR) (version 24.8.14.10512.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:45340) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe44f2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000001a1ea71d 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e774c 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9e7f 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:55.347171 [ 4162 ] {e0d22f6c-1002-4383-8314-f7ce935dbcec} 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]:57092). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe46b0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000001a1f93c7 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000001a1e89bc 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1da219 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 (version 24.8.14.10512.altinitytest (altinity build)) 2025.09.06 08:47:55.347611 [ 4162 ] {e0d22f6c-1002-4383-8314-f7ce935dbcec} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:57092). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe44f2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000001a1ea71d 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e774c 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9e7f 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:55.348225 [ 4162 ] {e0d22f6c-1002-4383-8314-f7ce935dbcec} TCPHandler: Client has gone away. 2025.09.06 08:47:55.349829 [ 4084 ] {ff62fadb-9200-4dc7-8733-981cde90b515} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.079619854 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016dfe206 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016dfd326 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x0000000017edfa01 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2e2888 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e24c8 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f683b 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 11. __tsan_thread_start_func @ 0x000000000758af2f 12. ? @ 0x00007fc4ea2adac3 13. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:55.361735 [ 4166 ] {82a823aa-3093-4165-b7eb-fbfaaf4d8503} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:45340). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe46b0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000001a1f93c7 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000001a1e89bc 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1da219 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 (version 24.8.14.10512.altinitytest (altinity build)) 2025.09.06 08:47:55.362118 [ 4166 ] {82a823aa-3093-4165-b7eb-fbfaaf4d8503} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:45340). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe44f2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000001a1ea71d 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e774c 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9e7f 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:55.362733 [ 4166 ] {82a823aa-3093-4165-b7eb-fbfaaf4d8503} TCPHandler: Client has gone away. 2025.09.06 08:47:55.385232 [ 4158 ] {b8f8a7ef-9748-4f73-a9c7-d4fac58e9b49} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:53864). (NETWORK_ERROR) (version 24.8.14.10512.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:53864) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe46b0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProgress() @ 0x000000001a1e7e89 6. ./build_docker/./src/Server/TCPHandler.cpp:1170: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e7ab3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9e7f 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:55.404496 [ 2909 ] {249192e2-730c-473c-8a37-40ba7390f1fc} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:52058). (NETWORK_ERROR) (version 24.8.14.10512.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:52058) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe44f2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000001a1ea71d 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e774c 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9e7f 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:55.405779 [ 4158 ] {b8f8a7ef-9748-4f73-a9c7-d4fac58e9b49} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:53864). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe46b0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000001a1f93c7 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000001a1e89bc 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1da219 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 (version 24.8.14.10512.altinitytest (altinity build)) 2025.09.06 08:47:55.406130 [ 4158 ] {b8f8a7ef-9748-4f73-a9c7-d4fac58e9b49} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:53864). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe46b0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProgress() @ 0x000000001a1e7e89 6. ./build_docker/./src/Server/TCPHandler.cpp:1170: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e7ab3 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9e7f 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:55.406744 [ 4158 ] {b8f8a7ef-9748-4f73-a9c7-d4fac58e9b49} TCPHandler: Client has gone away. 2025.09.06 08:47:55.424761 [ 2909 ] {249192e2-730c-473c-8a37-40ba7390f1fc} 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]:52058). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe46b0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000001a1f93c7 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000001a1e89bc 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1da219 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 (version 24.8.14.10512.altinitytest (altinity build)) 2025.09.06 08:47:55.425316 [ 2909 ] {249192e2-730c-473c-8a37-40ba7390f1fc} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:52058). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe2aad 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe44f2 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a05c54e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000001a1ea71d 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1e774c 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1d9e7f 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a1f9548 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6a2803 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6a3072 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e61c283 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e61a550 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e618a2a 14. __tsan_thread_start_func @ 0x000000000758af2f 15. ? @ 0x00007fc4ea2adac3 16. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:55.426242 [ 2909 ] {249192e2-730c-473c-8a37-40ba7390f1fc} TCPHandler: Client has gone away. 2025.09.06 08:47:56.770275 [ 4084 ] {849ee4b6-6e0e-428e-8811-b246c2c91f8c} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.017336799 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10512.altinitytest (altinity build)) (from [::1]:50138) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016dfe206 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016dfd326 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x0000000017edfa01 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2e2888 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e24c8 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f683b 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 11. __tsan_thread_start_func @ 0x000000000758af2f 12. ? @ 0x00007fc4ea2adac3 13. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:56.803326 [ 4084 ] {849ee4b6-6e0e-428e-8811-b246c2c91f8c} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.017336799 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016dfe206 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016dfd326 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x0000000017edfa01 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2e2888 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e24c8 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f683b 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 11. __tsan_thread_start_func @ 0x000000000758af2f 12. ? @ 0x00007fc4ea2adac3 13. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:58.297946 [ 4084 ] {67c321a3-8264-4c8f-a301-84564a155fe7} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.130627898 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10512.altinitytest (altinity build)) (from [::1]:50170) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016dfe206 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016dfd326 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x0000000017edfa01 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2e2888 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e24c8 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f683b 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 11. __tsan_thread_start_func @ 0x000000000758af2f 12. ? @ 0x00007fc4ea2adac3 13. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:58.384661 [ 4084 ] {67c321a3-8264-4c8f-a301-84564a155fe7} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.130627898 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016dfe206 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016dfd326 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x0000000017edfa01 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2e2888 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e24c8 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f683b 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 11. __tsan_thread_start_func @ 0x000000000758af2f 12. ? @ 0x00007fc4ea2adac3 13. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:59.899597 [ 2910 ] {45a35af8-817e-4d57-9936-2a7da0fbdc12} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.117150965 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10512.altinitytest (altinity build)) (from [::1]:50172) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016dfe206 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016dfd326 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x0000000017edfa01 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2e2888 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e24c8 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f683b 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 11. __tsan_thread_start_func @ 0x000000000758af2f 12. ? @ 0x00007fc4ea2adac3 13. ? @ 0x00007fc4ea33f850 2025.09.06 08:47:59.973191 [ 2910 ] {45a35af8-817e-4d57-9936-2a7da0fbdc12} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.117150965 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016dfe206 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016dfd326 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x0000000017edfa01 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2e2888 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e24c8 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f683b 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 11. __tsan_thread_start_func @ 0x000000000758af2f 12. ? @ 0x00007fc4ea2adac3 13. ? @ 0x00007fc4ea33f850 2025.09.06 08:48:01.551559 [ 2910 ] {bb041ed1-5aa3-4d10-81fe-5d3e7f64d69c} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.193969703 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10512.altinitytest (altinity build)) (from [::1]:50192) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016dfe206 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016dfd326 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x0000000017edfa01 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2e2888 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e24c8 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f683b 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 11. __tsan_thread_start_func @ 0x000000000758af2f 12. ? @ 0x00007fc4ea2adac3 13. ? @ 0x00007fc4ea33f850 2025.09.06 08:48:01.585514 [ 2910 ] {bb041ed1-5aa3-4d10-81fe-5d3e7f64d69c} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.193969703 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016dfe206 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016dfd326 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x0000000017edfa01 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2e2888 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e24c8 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f683b 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 11. __tsan_thread_start_func @ 0x000000000758af2f 12. ? @ 0x00007fc4ea2adac3 13. ? @ 0x00007fc4ea33f850 2025.09.06 08:48:03.051669 [ 2910 ] {552834c8-1881-4591-8ef4-b9ac043e6a35} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.013742832 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10512.altinitytest (altinity build)) (from [::1]:52126) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016dfe206 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016dfd326 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x0000000017edfa01 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2e2888 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e24c8 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f683b 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 11. __tsan_thread_start_func @ 0x000000000758af2f 12. ? @ 0x00007fc4ea2adac3 13. ? @ 0x00007fc4ea33f850 2025.09.06 08:48:03.064661 [ 2910 ] {552834c8-1881-4591-8ef4-b9ac043e6a35} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.013742832 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e595c03 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa09ff5 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761237e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016dfe206 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016dfd326 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x0000000017edfa01 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2e2888 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2e24c8 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f683b 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb15f7e 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb1df1c 11. __tsan_thread_start_func @ 0x000000000758af2f 12. ? @ 0x00007fc4ea2adac3 13. ? @ 0x00007fc4ea33f850 2025.09.06 08:55:40.189862 [ 353 ] {} Application: Closed all listening sockets. Waiting for 3 outstanding connections. 2025.09.06 08:55:45.098420 [ 353 ] {} Application: Closed connections. But 3 remain. Tip: To increase wait time add to config: 60 2025.09.06 08:55:46.014224 [ 353 ] {} Application: Will shutdown forcefully.