2024.12.16 19:42:20.464560 [ 391 ] {} Context: Server was built in debug mode. It will work slowly. 2024.12.16 19:42:20.497613 [ 391 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2024.12.16 19:42:20.500540 [ 391 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2024.12.16 19:42:20.500725 [ 391 ] {} Application: Integrity check of the executable skipped because the reference checksum could not be read. 2024.12.16 19:42:21.381573 [ 391 ] {} CloudPlacementInfo: Placement info has not been loaded 2024.12.16 19:42:21.777363 [ 391 ] {} KeeperLogStore: No logs exists in /var/lib/clickhouse/coordination/logs. It's Ok if it's the first run of clickhouse-keeper. 2024.12.16 19:42:21.778531 [ 391 ] {} KeeperLogStore: Removing all changelogs 2024.12.16 19:42:21.780377 [ 391 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2024.12.16 19:42:21.786624 [ 391 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2024.12.16 19:42:21.786739 [ 391 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2024.12.16 19:42:21.838272 [ 980 ] {} RaftInstance: Election timeout, initiate leader election 2024.12.16 19:42:21.939244 [ 391 ] {} Access(local_directory): File /var/lib/clickhouse/access/users.list doesn't exist 2024.12.16 19:42:21.939374 [ 391 ] {} Access(local_directory): Recovering lists in directory /var/lib/clickhouse/access/ 2024.12.16 19:42:22.522323 [ 391 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2024.12.16 19:42:25.929207 [ 394 ] {24585231-c423-4b35-a7c1-1b68a35f8dab} 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. 2024.12.16 19:42:34.740332 [ 394 ] {579bf2ea-7667-4a28-9720-3c08a8bc12d9} 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. 2024.12.16 19:48:30.321002 [ 394 ] {1d65ecf5-1dc9-49ba-9308-b584003e5691} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00 million, current rows: 8.88 million. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:47720) (comment: 00175_counting_resources_in_subqueries.sql) (in query: SELECT 1 = (SELECT count() FROM test.hits WHERE NOT ignore(AdvEngineID));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000019ec2128 6. /build/src/QueryPipeline/SizeLimits.cpp:25: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec1c4c 7. /build/src/QueryPipeline/SizeLimits.cpp:65: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000019ec1f99 8. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:258: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001dd50863 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1971: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd6259e 10. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd08c90 11. /build/src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd3371f 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001b508741 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001b50849b 14. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:2110: DB::(anonymous namespace)::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b0bf908 15. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6524: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b0a290d 16. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6640: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b0a0a21 17. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:5542: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b0b79f8 18. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6487: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b0a24ea 19. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6640: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b0a0a21 20. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6901: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b0ab1c7 21. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:8173: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b09cd43 22. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::(anonymous namespace)::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001b09af74 23. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:8408: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001b09ac33 24. /build/src/Analyzer/QueryTreePassManager.cpp:186: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001b08c3a6 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:142: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001b507dac 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001b5069e6 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001b509db7 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: DB::registerInterpreterSelectQueryAnalyzer(DB::InterpreterFactory&)::$_0::operator()(DB::InterpreterFactory::Arguments const&) const @ 0x000000001b50924c 29. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001b5091fd 30. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:470: ? @ 0x000000001b50919d 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001b50915d 2024.12.16 19:48:30.321965 [ 394 ] {1d65ecf5-1dc9-49ba-9308-b584003e5691} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00 million, current rows: 8.88 million. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000019ec2128 6. /build/src/QueryPipeline/SizeLimits.cpp:25: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec1c4c 7. /build/src/QueryPipeline/SizeLimits.cpp:65: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000019ec1f99 8. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:258: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001dd50863 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1971: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd6259e 10. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd08c90 11. /build/src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd3371f 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001b508741 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001b50849b 14. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:2110: DB::(anonymous namespace)::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b0bf908 15. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6524: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b0a290d 16. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6640: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b0a0a21 17. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:5542: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b0b79f8 18. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6487: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b0a24ea 19. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6640: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b0a0a21 20. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6901: DB::(anonymous namespace)::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b0ab1c7 21. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:8173: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b09cd43 22. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::(anonymous namespace)::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001b09af74 23. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:8408: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001b09ac33 24. /build/src/Analyzer/QueryTreePassManager.cpp:186: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001b08c3a6 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:142: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001b507dac 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001b5069e6 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001b509db7 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: DB::registerInterpreterSelectQueryAnalyzer(DB::InterpreterFactory&)::$_0::operator()(DB::InterpreterFactory::Arguments const&) const @ 0x000000001b50924c 29. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001b5091fd 30. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:470: ? @ 0x000000001b50919d 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001b50915d 2024.12.16 19:48:30.528791 [ 394 ] {349293b1-1d83-41a6-a600-8e261ef2ca21} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00 million, current rows: 8.88 million. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:47720) (comment: 00175_counting_resources_in_subqueries.sql) (in query: SELECT 1 IN (SELECT count() FROM test.hits WHERE NOT ignore(AdvEngineID));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000019ec2128 6. /build/src/QueryPipeline/SizeLimits.cpp:25: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec1c4c 7. /build/src/QueryPipeline/SizeLimits.cpp:65: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000019ec1f99 8. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:258: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001dd50863 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1971: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd6259e 10. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd08c90 11. /build/src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd3371f 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001b508741 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001b50849b 14. /build/src/Interpreters/executeQuery.cpp:1195: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001bbb26d7 15. /build/src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001bbac7aa 16. /build/src/Server/TCPHandler.cpp:517: DB::TCPHandler::runImpl() @ 0x000000001d46fe60 17. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d4870c5 18. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228aead9 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228af328 20. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a86654 21. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a833fa 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a8213e 23. ? @ 0x00007ff147457ac3 24. ? @ 0x00007ff1474e9850 2024.12.16 19:48:30.529637 [ 394 ] {349293b1-1d83-41a6-a600-8e261ef2ca21} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00 million, current rows: 8.88 million. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000019ec2128 6. /build/src/QueryPipeline/SizeLimits.cpp:25: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec1c4c 7. /build/src/QueryPipeline/SizeLimits.cpp:65: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000019ec1f99 8. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:258: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001dd50863 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1971: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd6259e 10. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd08c90 11. /build/src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd3371f 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001b508741 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001b50849b 14. /build/src/Interpreters/executeQuery.cpp:1195: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001bbb26d7 15. /build/src/Interpreters/executeQuery.cpp:1374: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001bbac7aa 16. /build/src/Server/TCPHandler.cpp:517: DB::TCPHandler::runImpl() @ 0x000000001d46fe60 17. /build/src/Server/TCPHandler.cpp:2339: DB::TCPHandler::run() @ 0x000000001d4870c5 18. /build/base/poco/Net/src/TCPServerConnection.cpp:43: Poco::Net::TCPServerConnection::start() @ 0x00000000228aead9 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x00000000228af328 20. /build/base/poco/Foundation/src/ThreadPool.cpp:188: Poco::PooledThread::run() @ 0x0000000022a86654 21. /build/base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x0000000022a833fa 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000022a8213e 23. ? @ 0x00007ff147457ac3 24. ? @ 0x00007ff1474e9850 2024.12.16 19:48:31.716477 [ 394 ] {d84c5d33-fff5-4d2c-b1a3-8345cb7990c4} executeQuery: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 15.00 million, current rows: 17.33 million: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:47720) (comment: 00175_counting_resources_in_subqueries.sql) (in query: SELECT count() IN (SELECT count() FROM test.hits WHERE NOT ignore(AdvEngineID)) FROM test.hits WHERE NOT ignore(AdvEngineID);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000019ec2128 6. /build/src/QueryPipeline/SizeLimits.cpp:25: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec1c4c 7. /build/src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000019e94084 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::executeJob(DB::ExecutingGraph::Node*, DB::ReadProgressCallback*) @ 0x000000001d533e71 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:95: DB::ExecutionThreadContext::executeTask() @ 0x000000001d533920 10. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001d515ea1 11. /build/src/Processors/Executors/PipelineExecutor.cpp:239: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000001d516237 12. /build/src/Processors/Executors/PipelineExecutor.cpp:373: DB::PipelineExecutor::spawnThreads()::$_0::operator()() const @ 0x000000001d5171d8 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d517135 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d517115 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5170f5 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5170c0 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 19. /build/src/Common/ThreadPool.cpp:526: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000133d9082 20. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133e2ec4 21. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e2e95 22. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&, std::__tuple_indices<>) @ 0x00000000133e2e79 23. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&) @ 0x00000000133e2d1d 24. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x00000000133e2be5 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e2b55 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x00000000133e2b35 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x00000000133e2b15 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000133e2ae0 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 31. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 2024.12.16 19:48:31.790670 [ 394 ] {d84c5d33-fff5-4d2c-b1a3-8345cb7990c4} TCPHandler: Code: 158. DB::Exception: Limit for rows or bytes to read exceeded, max rows: 15.00 million, current rows: 17.33 million: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000019ec2128 6. /build/src/QueryPipeline/SizeLimits.cpp:25: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec1c4c 7. /build/src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000019e94084 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::executeJob(DB::ExecutingGraph::Node*, DB::ReadProgressCallback*) @ 0x000000001d533e71 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:95: DB::ExecutionThreadContext::executeTask() @ 0x000000001d533920 10. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001d515ea1 11. /build/src/Processors/Executors/PipelineExecutor.cpp:239: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000001d516237 12. /build/src/Processors/Executors/PipelineExecutor.cpp:373: DB::PipelineExecutor::spawnThreads()::$_0::operator()() const @ 0x000000001d5171d8 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d517135 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d517115 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5170f5 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5170c0 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 19. /build/src/Common/ThreadPool.cpp:526: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000133d9082 20. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133e2ec4 21. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e2e95 22. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&, std::__tuple_indices<>) @ 0x00000000133e2e79 23. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&) @ 0x00000000133e2d1d 24. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x00000000133e2be5 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e2b55 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x00000000133e2b35 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x00000000133e2b15 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000133e2ae0 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 31. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 2024.12.16 19:48:32.037624 [ 394 ] {3c994084-b28a-4f2f-9d07-849eb3d850e9} executeQuery: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00 million, current rows: 8.88 million. (TOO_MANY_ROWS) (version 24.3.12.76.altinitystable) (from [::1]:47720) (comment: 00175_counting_resources_in_subqueries.sql) (in query: SELECT count() FROM test.hits WHERE CounterID > (SELECT count() FROM test.hits WHERE NOT ignore(AdvEngineID));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000019ec2128 6. /build/src/QueryPipeline/SizeLimits.cpp:25: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec1c4c 7. /build/src/QueryPipeline/SizeLimits.cpp:65: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000019ec1f99 8. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:258: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001dd50863 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1971: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd6259e 10. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd08c90 11. /build/src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd3371f 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001b508741 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001b50849b 14. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:2110: DB::(anonymous namespace)::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b0bf908 15. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6524: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b0a290d 16. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6640: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b0a0a21 17. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:5542: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b0b79f8 18. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6487: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b0a24ea 19. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:8198: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b09d077 20. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::(anonymous namespace)::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001b09af74 21. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:8408: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001b09ac33 22. /build/src/Analyzer/QueryTreePassManager.cpp:186: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001b08c3a6 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:142: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001b507dac 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001b5069e6 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001b509db7 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: DB::registerInterpreterSelectQueryAnalyzer(DB::InterpreterFactory&)::$_0::operator()(DB::InterpreterFactory::Arguments const&) const @ 0x000000001b50924c 27. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001b5091fd 28. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:470: ? @ 0x000000001b50919d 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001b50915d 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b509125 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001b428b1e 2024.12.16 19:48:32.038575 [ 394 ] {3c994084-b28a-4f2f-9d07-849eb3d850e9} TCPHandler: Code: 158. DB::Exception: Limit for rows (controlled by 'max_rows_to_read' setting) exceeded, max rows: 1.00 million, current rows: 8.88 million. (TOO_MANY_ROWS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000019ec2128 6. /build/src/QueryPipeline/SizeLimits.cpp:25: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec1c4c 7. /build/src/QueryPipeline/SizeLimits.cpp:65: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int) const @ 0x0000000019ec1f99 8. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:258: DB::ReadFromMergeTree::AnalysisResult::checkLimits(DB::Settings const&, DB::SelectQueryInfo const&) const @ 0x000000001dd50863 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1971: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd6259e 10. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd08c90 11. /build/src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001dd3371f 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000001b508741 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:221: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001b50849b 14. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:2110: DB::(anonymous namespace)::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b0bf908 15. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6524: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b0a290d 16. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6640: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b0a0a21 17. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:5542: DB::(anonymous namespace)::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b0b79f8 18. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:6487: DB::(anonymous namespace)::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::(anonymous namespace)::IdentifierResolveScope&, bool, bool) @ 0x000000001b0a24ea 19. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:8198: DB::(anonymous namespace)::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::(anonymous namespace)::IdentifierResolveScope&) @ 0x000000001b09d077 20. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:1150: DB::(anonymous namespace)::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001b09af74 21. /build/src/Analyzer/Passes/QueryAnalysisPass.cpp:8408: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000001b09ac33 22. /build/src/Analyzer/QueryTreePassManager.cpp:186: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001b08c3a6 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:142: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001b507dac 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001b5069e6 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15000]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000001b509db7 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:270: DB::registerInterpreterSelectQueryAnalyzer(DB::InterpreterFactory&)::$_0::operator()(DB::InterpreterFactory::Arguments const&) const @ 0x000000001b50924c 27. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001b5091fd 28. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:470: ? @ 0x000000001b50919d 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001b50915d 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001b509125 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x000000001b428b1e 2024.12.16 19:48:32.275283 [ 394 ] {c51daeb1-0d2a-49d5-9e1a-9c5dcfcde1a4} 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.3.12.76.altinitystable) (from [::1]:47720) (comment: 00175_counting_resources_in_subqueries.sql) (in query: SELECT count() FROM test.hits WHERE CounterID < (SELECT count() FROM test.hits WHERE NOT ignore(AdvEngineID));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000019ec2128 6. /build/src/QueryPipeline/SizeLimits.cpp:25: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec1c4c 7. /build/src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000019e94084 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::executeJob(DB::ExecutingGraph::Node*, DB::ReadProgressCallback*) @ 0x000000001d533e71 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:95: DB::ExecutionThreadContext::executeTask() @ 0x000000001d533920 10. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001d515ea1 11. /build/src/Processors/Executors/PipelineExecutor.cpp:239: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000001d516237 12. /build/src/Processors/Executors/PipelineExecutor.cpp:373: DB::PipelineExecutor::spawnThreads()::$_0::operator()() const @ 0x000000001d5171d8 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d517135 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d517115 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5170f5 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5170c0 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 19. /build/src/Common/ThreadPool.cpp:526: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000133d9082 20. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133e2ec4 21. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e2e95 22. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&, std::__tuple_indices<>) @ 0x00000000133e2e79 23. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&) @ 0x00000000133e2d1d 24. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x00000000133e2be5 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e2b55 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x00000000133e2b35 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x00000000133e2b15 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000133e2ae0 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 31. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 2024.12.16 19:48:32.285327 [ 394 ] {c51daeb1-0d2a-49d5-9e1a-9c5dcfcde1a4} 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. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000019ec2128 6. /build/src/QueryPipeline/SizeLimits.cpp:25: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec1c4c 7. /build/src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000019e94084 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::executeJob(DB::ExecutingGraph::Node*, DB::ReadProgressCallback*) @ 0x000000001d533e71 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:95: DB::ExecutionThreadContext::executeTask() @ 0x000000001d533920 10. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001d515ea1 11. /build/src/Processors/Executors/PipelineExecutor.cpp:239: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000001d516237 12. /build/src/Processors/Executors/PipelineExecutor.cpp:373: DB::PipelineExecutor::spawnThreads()::$_0::operator()() const @ 0x000000001d5171d8 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d517135 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d517115 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5170f5 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5170c0 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 19. /build/src/Common/ThreadPool.cpp:526: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000133d9082 20. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133e2ec4 21. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e2e95 22. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&, std::__tuple_indices<>) @ 0x00000000133e2e79 23. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&) @ 0x00000000133e2d1d 24. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x00000000133e2be5 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e2b55 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x00000000133e2b35 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x00000000133e2b15 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000133e2ae0 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 31. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 2024.12.16 19:58:29.647880 [ 2647 ] {99ae0a5c-3e2c-411a-8d70-0ad271d07625} executeQuery: Code: 307. DB::Exception: Limit for rows or bytes to read exceeded, max bytes: 572.20 MiB, current bytes: 579.07 MiB: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_BYTES) (version 24.3.12.76.altinitystable) (from [::1]:37558) (comment: 00091_prewhere_two_conditions.sql) (in query: SELECT uniq(URL) FROM test.hits WHERE toTimeZone(EventTime, 'Asia/Dubai') >= '2014-03-20 00:00:00' AND toTimeZone(EventTime, 'Asia/Dubai') < '2014-03-21 00:00:00';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000019ec2348 6. /build/src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec1e27 7. /build/src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000019e94084 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::executeJob(DB::ExecutingGraph::Node*, DB::ReadProgressCallback*) @ 0x000000001d533e71 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:95: DB::ExecutionThreadContext::executeTask() @ 0x000000001d533920 10. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001d515ea1 11. /build/src/Processors/Executors/PipelineExecutor.cpp:239: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000001d516237 12. /build/src/Processors/Executors/PipelineExecutor.cpp:373: DB::PipelineExecutor::spawnThreads()::$_0::operator()() const @ 0x000000001d5171d8 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d517135 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d517115 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5170f5 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5170c0 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 19. /build/src/Common/ThreadPool.cpp:526: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000133d9082 20. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133e2ec4 21. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e2e95 22. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&, std::__tuple_indices<>) @ 0x00000000133e2e79 23. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&) @ 0x00000000133e2d1d 24. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x00000000133e2be5 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e2b55 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x00000000133e2b35 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x00000000133e2b15 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000133e2ae0 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 31. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 2024.12.16 19:58:29.781626 [ 2647 ] {99ae0a5c-3e2c-411a-8d70-0ad271d07625} TCPHandler: Code: 307. DB::Exception: Limit for rows or bytes to read exceeded, max bytes: 572.20 MiB, current bytes: 579.07 MiB: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000019ec2348 6. /build/src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec1e27 7. /build/src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000019e94084 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::executeJob(DB::ExecutingGraph::Node*, DB::ReadProgressCallback*) @ 0x000000001d533e71 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:95: DB::ExecutionThreadContext::executeTask() @ 0x000000001d533920 10. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001d515ea1 11. /build/src/Processors/Executors/PipelineExecutor.cpp:239: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000001d516237 12. /build/src/Processors/Executors/PipelineExecutor.cpp:373: DB::PipelineExecutor::spawnThreads()::$_0::operator()() const @ 0x000000001d5171d8 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d517135 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d517115 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5170f5 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5170c0 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 19. /build/src/Common/ThreadPool.cpp:526: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000133d9082 20. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133e2ec4 21. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e2e95 22. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&, std::__tuple_indices<>) @ 0x00000000133e2e79 23. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&) @ 0x00000000133e2d1d 24. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x00000000133e2be5 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e2b55 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x00000000133e2b35 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x00000000133e2b15 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000133e2ae0 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 31. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 2024.12.16 19:58:30.304461 [ 2647 ] {86d71ccd-1d27-43ab-a439-9428e6088c2c} executeQuery: Code: 307. DB::Exception: Limit for rows or bytes to read exceeded, max bytes: 572.20 MiB, current bytes: 577.73 MiB: While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (TOO_MANY_BYTES) (version 24.3.12.76.altinitystable) (from [::1]:37558) (comment: 00091_prewhere_two_conditions.sql) (in query: SELECT uniq(URL) FROM test.hits WHERE toTimeZone(EventTime, 'Asia/Dubai') >= '2014-03-20 00:00:00' AND URL != '' AND toTimeZone(EventTime, 'Asia/Dubai') < '2014-03-21 00:00:00';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000019ec2348 6. /build/src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec1e27 7. /build/src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000019e94084 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::executeJob(DB::ExecutingGraph::Node*, DB::ReadProgressCallback*) @ 0x000000001d533e71 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:95: DB::ExecutionThreadContext::executeTask() @ 0x000000001d533920 10. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001d515ea1 11. /build/src/Processors/Executors/PipelineExecutor.cpp:239: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000001d516237 12. /build/src/Processors/Executors/PipelineExecutor.cpp:373: DB::PipelineExecutor::spawnThreads()::$_0::operator()() const @ 0x000000001d5171d8 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d517135 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d517115 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5170f5 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5170c0 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 19. /build/src/Common/ThreadPool.cpp:526: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000133d9082 20. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133e2ec4 21. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e2e95 22. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&, std::__tuple_indices<>) @ 0x00000000133e2e79 23. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&) @ 0x00000000133e2d1d 24. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x00000000133e2be5 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e2b55 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x00000000133e2b35 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x00000000133e2b15 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000133e2ae0 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 31. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 2024.12.16 19:58:30.352975 [ 2647 ] {86d71ccd-1d27-43ab-a439-9428e6088c2c} TCPHandler: Code: 307. DB::Exception: Limit for rows or bytes to read exceeded, max bytes: 572.20 MiB, current bytes: 577.73 MiB: While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000019ec2348 6. /build/src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec1e27 7. /build/src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000019e94084 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::executeJob(DB::ExecutingGraph::Node*, DB::ReadProgressCallback*) @ 0x000000001d533e71 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:95: DB::ExecutionThreadContext::executeTask() @ 0x000000001d533920 10. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001d515ea1 11. /build/src/Processors/Executors/PipelineExecutor.cpp:239: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000001d516237 12. /build/src/Processors/Executors/PipelineExecutor.cpp:373: DB::PipelineExecutor::spawnThreads()::$_0::operator()() const @ 0x000000001d5171d8 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d517135 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d517115 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5170f5 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5170c0 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 19. /build/src/Common/ThreadPool.cpp:526: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000133d9082 20. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133e2ec4 21. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e2e95 22. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&, std::__tuple_indices<>) @ 0x00000000133e2e79 23. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&) @ 0x00000000133e2d1d 24. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x00000000133e2be5 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e2b55 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x00000000133e2b35 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x00000000133e2b15 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000133e2ae0 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 31. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 2024.12.16 19:58:30.887825 [ 2647 ] {8b4988ab-4f46-4740-ba4d-fc325a8f0fd5} executeQuery: Code: 307. DB::Exception: Limit for rows or bytes to read exceeded, max bytes: 572.20 MiB, current bytes: 574.62 MiB: While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (TOO_MANY_BYTES) (version 24.3.12.76.altinitystable) (from [::1]:37558) (comment: 00091_prewhere_two_conditions.sql) (in query: SELECT uniq(URL) FROM test.hits PREWHERE toTimeZone(EventTime, 'Asia/Dubai') >= '2014-03-20 00:00:00' AND URL != '' AND toTimeZone(EventTime, 'Asia/Dubai') < '2014-03-21 00:00:00';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000019ec2348 6. /build/src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec1e27 7. /build/src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000019e94084 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::executeJob(DB::ExecutingGraph::Node*, DB::ReadProgressCallback*) @ 0x000000001d533e71 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:95: DB::ExecutionThreadContext::executeTask() @ 0x000000001d533920 10. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001d515ea1 11. /build/src/Processors/Executors/PipelineExecutor.cpp:239: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000001d516237 12. /build/src/Processors/Executors/PipelineExecutor.cpp:373: DB::PipelineExecutor::spawnThreads()::$_0::operator()() const @ 0x000000001d5171d8 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d517135 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d517115 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5170f5 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5170c0 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 19. /build/src/Common/ThreadPool.cpp:526: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000133d9082 20. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133e2ec4 21. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e2e95 22. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&, std::__tuple_indices<>) @ 0x00000000133e2e79 23. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&) @ 0x00000000133e2d1d 24. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x00000000133e2be5 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e2b55 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x00000000133e2b35 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x00000000133e2b15 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000133e2ae0 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 31. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 2024.12.16 19:58:30.942944 [ 2647 ] {8b4988ab-4f46-4740-ba4d-fc325a8f0fd5} TCPHandler: Code: 307. DB::Exception: Limit for rows or bytes to read exceeded, max bytes: 572.20 MiB, current bytes: 574.62 MiB: While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (TOO_MANY_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000019ec2348 6. /build/src/QueryPipeline/SizeLimits.cpp:36: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000019ec1e27 7. /build/src/QueryPipeline/ReadProgressCallback.cpp:109: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000019e94084 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::executeJob(DB::ExecutingGraph::Node*, DB::ReadProgressCallback*) @ 0x000000001d533e71 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:95: DB::ExecutionThreadContext::executeTask() @ 0x000000001d533920 10. /build/src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001d515ea1 11. /build/src/Processors/Executors/PipelineExecutor.cpp:239: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x000000001d516237 12. /build/src/Processors/Executors/PipelineExecutor.cpp:373: DB::PipelineExecutor::spawnThreads()::$_0::operator()() const @ 0x000000001d5171d8 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d517135 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d517115 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5170f5 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5170c0 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 19. /build/src/Common/ThreadPool.cpp:526: ThreadPoolImpl>::worker(std::__list_iterator, void*>) @ 0x00000000133d9082 20. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133e2ec4 21. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e2e95 22. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&, std::__tuple_indices<>) @ 0x00000000133e2e79 23. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()&, std::tuple<>&>(void&&, std::tuple<>&) @ 0x00000000133e2d1d 24. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(void&&)::'lambda'()::operator()() @ 0x00000000133e2be5 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133e2b55 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x00000000133e2b35 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x00000000133e2b15 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000133e2ae0 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 31. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 2024.12.16 19:58:38.506166 [ 1922 ] {518ec6cb-46b3-44ad-83b7-00a6700de6e0} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.062720612 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:55110) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e967cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e95bd9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e95ae8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a645e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d514dc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51547f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d514d3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d539d70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d539bdf 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539b55 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d539b39 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d539a9d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5399a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539915 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5398f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5398d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5398a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dd304 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dd2b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dd27d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dd082 29. ? @ 0x00007ff147457ac3 30. ? @ 0x00007ff1474e9850 2024.12.16 19:58:38.686353 [ 1922 ] {518ec6cb-46b3-44ad-83b7-00a6700de6e0} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.062720612 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e967cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e95bd9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e95ae8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a645e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d514dc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51547f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d514d3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d539d70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d539bdf 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539b55 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d539b39 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d539a9d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5399a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539915 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5398f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5398d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5398a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dd304 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dd2b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dd27d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dd082 29. ? @ 0x00007ff147457ac3 30. ? @ 0x00007ff1474e9850 2024.12.16 19:58:43.186225 [ 1922 ] {335c11aa-4ef3-4719-b1d7-abecb47632c5} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.017127278 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:58594) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e967cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e95bd9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e95ae8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a645e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d514dc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51547f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d514d3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d539d70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d539bdf 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539b55 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d539b39 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d539a9d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5399a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539915 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5398f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5398d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5398a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dd304 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dd2b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dd27d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dd082 29. ? @ 0x00007ff147457ac3 30. ? @ 0x00007ff1474e9850 2024.12.16 19:58:43.508875 [ 1922 ] {335c11aa-4ef3-4719-b1d7-abecb47632c5} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.017127278 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e967cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e95bd9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e95ae8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a645e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d514dc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51547f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d514d3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d539d70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d539bdf 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539b55 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d539b39 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d539a9d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5399a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539915 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5398f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5398d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5398a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dd304 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dd2b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dd27d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dd082 29. ? @ 0x00007ff147457ac3 30. ? @ 0x00007ff1474e9850 2024.12.16 19:58:47.717285 [ 1922 ] {324a01c0-69f2-4ea6-beb0-7612a01abcac} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.025943549 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:58600) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e967cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e95bd9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e95ae8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a645e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d514dc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51547f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d514d3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d539d70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d539bdf 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539b55 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d539b39 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d539a9d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5399a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539915 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5398f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5398d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5398a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dd304 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dd2b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dd27d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dd082 29. ? @ 0x00007ff147457ac3 30. ? @ 0x00007ff1474e9850 2024.12.16 19:58:47.926468 [ 1922 ] {324a01c0-69f2-4ea6-beb0-7612a01abcac} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.025943549 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e967cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e95bd9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e95ae8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a645e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d514dc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51547f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d514d3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d539d70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d539bdf 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539b55 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d539b39 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d539a9d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5399a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539915 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5398f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5398d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5398a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dd304 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dd2b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dd27d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dd082 29. ? @ 0x00007ff147457ac3 30. ? @ 0x00007ff1474e9850 2024.12.16 19:58:52.269285 [ 1922 ] {f3abf4d9-bf6b-4dbb-8d03-1b23d903fcce} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.039225838 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:54922) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e967cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e95bd9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e95ae8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a645e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d514dc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51547f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d514d3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d539d70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d539bdf 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539b55 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d539b39 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d539a9d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5399a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539915 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5398f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5398d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5398a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dd304 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dd2b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dd27d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dd082 29. ? @ 0x00007ff147457ac3 30. ? @ 0x00007ff1474e9850 2024.12.16 19:58:52.378637 [ 1922 ] {f3abf4d9-bf6b-4dbb-8d03-1b23d903fcce} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.039225838 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e967cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e95bd9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e95ae8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a645e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d514dc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51547f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d514d3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d539d70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d539bdf 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539b55 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d539b39 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d539a9d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5399a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539915 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5398f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5398d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5398a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dd304 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dd2b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dd27d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dd082 29. ? @ 0x00007ff147457ac3 30. ? @ 0x00007ff1474e9850 2024.12.16 19:58:57.029752 [ 1922 ] {6c516c6c-bf61-41a7-b971-b8bfa8e681a9} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.015462837 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:54934) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e967cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e95bd9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e95ae8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a645e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d514dc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51547f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d514d3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d539d70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d539bdf 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539b55 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d539b39 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d539a9d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5399a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539915 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5398f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5398d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5398a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dd304 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dd2b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dd27d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dd082 29. ? @ 0x00007ff147457ac3 30. ? @ 0x00007ff1474e9850 2024.12.16 19:58:57.318801 [ 1922 ] {6c516c6c-bf61-41a7-b971-b8bfa8e681a9} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.015462837 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e967cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e95bd9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e95ae8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a645e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d514dc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51547f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d514d3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d539d70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d539bdf 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539b55 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d539b39 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d539a9d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5399a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539915 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5398f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5398d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5398a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dd304 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dd2b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dd27d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dd082 29. ? @ 0x00007ff147457ac3 30. ? @ 0x00007ff1474e9850 2024.12.16 19:59:01.589421 [ 1922 ] {916df048-5c93-44ec-8979-8a4770473ed5} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.080230629 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:39044) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6,7}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e967cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e95bd9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e95ae8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a645e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d514dc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51547f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d514d3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d539d70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d539bdf 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539b55 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d539b39 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d539a9d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5399a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539915 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5398f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5398d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5398a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dd304 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dd2b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dd27d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dd082 29. ? @ 0x00007ff147457ac3 30. ? @ 0x00007ff1474e9850 2024.12.16 19:59:01.934554 [ 1922 ] {916df048-5c93-44ec-8979-8a4770473ed5} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.080230629 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e967cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e95bd9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e95ae8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a645e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d514dc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51547f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d514d3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d539d70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d539bdf 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539b55 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d539b39 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d539a9d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5399a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539915 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5398f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5398d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5398a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dd304 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dd2b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dd27d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dd082 29. ? @ 0x00007ff147457ac3 30. ? @ 0x00007ff1474e9850 2024.12.16 19:59:06.569900 [ 1923 ] {fae63c02-375c-4621-afdc-647e2946f47c} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.029232676 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:39058) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6,7,8}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e967cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e95bd9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e95ae8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a645e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d514dc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51547f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d514d3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d539d70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d539bdf 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539b55 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d539b39 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d539a9d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5399a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539915 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5398f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5398d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5398a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dd304 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dd2b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dd27d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dd082 29. ? @ 0x00007ff147457ac3 30. ? @ 0x00007ff1474e9850 2024.12.16 19:59:06.792642 [ 1923 ] {fae63c02-375c-4621-afdc-647e2946f47c} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.029232676 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e967cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e95bd9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e95ae8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a645e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d514dc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51547f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d514d3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d539d70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d539bdf 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539b55 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d539b39 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d539a9d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5399a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539915 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5398f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5398d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5398a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dd304 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dd2b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dd27d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dd082 29. ? @ 0x00007ff147457ac3 30. ? @ 0x00007ff1474e9850 2024.12.16 19:59:11.309354 [ 1923 ] {cc7e5466-4d94-4ea9-ac81-8bfeb2d3de30} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.066542965 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:36918) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6,7,8,9}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e967cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e95bd9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e95ae8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a645e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d514dc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d514216 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d539d70 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d539bdf 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539b55 14. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d539b39 15. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d539a9d 16. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5399a7 17. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539915 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5398f5 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5398d5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5398a0 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 23. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 24. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dd304 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dd2b5 26. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dd27d 27. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dd082 28. ? @ 0x00007ff147457ac3 29. ? @ 0x00007ff1474e9850 2024.12.16 19:59:11.368931 [ 1923 ] {cc7e5466-4d94-4ea9-ac81-8bfeb2d3de30} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.066542965 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e967cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e95bd9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e95ae8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a645e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d514dc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:103: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d514216 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d539d70 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d539bdf 13. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539b55 14. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d539b39 15. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d539a9d 16. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5399a7 17. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539915 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5398f5 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5398d5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5398a0 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 23. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 24. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dd304 25. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dd2b5 26. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dd27d 27. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dd082 28. ? @ 0x00007ff147457ac3 29. ? @ 0x00007ff1474e9850 2024.12.16 19:59:16.101947 [ 1923 ] {39e8ed55-548e-4cf8-a8c2-57f431c75ab7} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.03520188 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.3.12.76.altinitystable) (from [::1]:36930) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6,7,8,9,10}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e967cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e95bd9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e95ae8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a645e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d514dc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51547f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d514d3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d539d70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d539bdf 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539b55 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d539b39 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d539a9d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5399a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539915 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5398f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5398d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5398a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dd304 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dd2b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dd27d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dd082 29. ? @ 0x00007ff147457ac3 30. ? @ 0x00007ff1474e9850 2024.12.16 19:59:16.326887 [ 1923 ] {39e8ed55-548e-4cf8-a8c2-57f431c75ab7} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.03520188 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/exception:141: std::exception::capture() @ 0x000000000a8f9382 1. /build/contrib/llvm-project/libcxx/include/exception:116: std::exception::exception[abi:v15000]() @ 0x000000000a8f934d 2. /build/base/poco/Foundation/src/Exception.cpp:27: Poco::Exception::Exception(String const&, int) @ 0x0000000022a068a0 3. /build/src/Common/Exception.cpp:94: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x00000000132bb52e 4. /build/src/Common/Exception.h:90: DB::Exception::Exception(String&&, int, bool) @ 0x000000000a8eff2a 5. /build/src/Common/Exception.h:109: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e967cc 6. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:111: bool DB::handleOverflowMode(DB::OverflowMode, int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000019e95bd9 7. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:127: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000019e95ae8 8. /build/src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x000000001b6a645e 9. /build/src/Processors/Executors/PipelineExecutor.cpp:186: DB::PipelineExecutor::checkTimeLimit() @ 0x000000001d514dc0 10. /build/src/Processors/Executors/PipelineExecutor.cpp:196: DB::PipelineExecutor::finalizeExecution() @ 0x000000001d51547f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:131: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001d514d3e 12. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:83: DB::threadFunction(DB::PullingAsyncPipelineExecutor::Data&, std::shared_ptr, unsigned long, bool) @ 0x000000001d539d70 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:110: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0::operator()() const @ 0x000000001d539bdf 14. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539b55 15. /build/contrib/llvm-project/libcxx/include/tuple:1789: decltype(auto) std::__apply_tuple_impl[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&, std::__tuple_indices<>) @ 0x000000001d539b39 16. /build/contrib/llvm-project/libcxx/include/tuple:1798: decltype(auto) std::apply[abi:v15000]&>(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&, std::tuple<>&) @ 0x000000001d539a9d 17. /build/src/Common/ThreadPool.h:225: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'()::operator()() @ 0x000000001d5399a7 18. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x000000001d539915 19. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:480: ? @ 0x000000001d5398f5 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:235: ? @ 0x000000001d5398d5 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001d5398a0 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x0000000011b441b6 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:1187: ? @ 0x0000000011b43df5 24. /build/src/Common/ThreadPool.cpp:536: ThreadPoolImpl::worker(std::__list_iterator) @ 0x00000000133d58b1 25. /build/src/Common/ThreadPool.cpp:253: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()::operator()() const @ 0x00000000133dd304 26. /build/contrib/llvm-project/libcxx/include/__functional/invoke.h:394: ? @ 0x00000000133dd2b5 27. /build/contrib/llvm-project/libcxx/include/thread:285: void std::__thread_execute[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>(std::tuple::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>&, std::__tuple_indices<>) @ 0x00000000133dd27d 28. /build/contrib/llvm-project/libcxx/include/thread:295: void* std::__thread_proxy[abi:v15000]>, void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda0'()>>(void*) @ 0x00000000133dd082 29. ? @ 0x00007ff147457ac3 30. ? @ 0x00007ff1474e9850 2024.12.16 20:08:42.416133 [ 391 ] {} Application: Closed all listening sockets. Waiting for 4 outstanding connections. 2024.12.16 20:08:47.321542 [ 391 ] {} Application: Closed connections. But 3 remain. Tip: To increase wait time add to config: 60 2024.12.16 20:08:51.560278 [ 391 ] {} Application: Will shutdown forcefully.