2025.10.23 23:44:24.359489 [ 428 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.10.23 23:44:24.359636 [ 428 ] {} Context: Server was built with thread sanitizer. It will work slowly. 2025.10.23 23:44:24.581349 [ 428 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.10.23 23:44:24.584064 [ 428 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.10.23 23:44:27.734064 [ 428 ] {} KeeperLogStore: No logs exists in /var/lib/clickhouse/coordination/logs. It's Ok if it's the first run of clickhouse-keeper. 2025.10.23 23:44:27.736246 [ 428 ] {} KeeperLogStore: Removing all changelogs 2025.10.23 23:44:27.739304 [ 428 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.10.23 23:44:27.759316 [ 428 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.10.23 23:44:27.759416 [ 428 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.10.23 23:44:27.811447 [ 1030 ] {} RaftInstance: Election timeout, initiate leader election 2025.10.23 23:44:28.093223 [ 428 ] {} Access(local_directory): File /var/lib/clickhouse/access/users.list doesn't exist 2025.10.23 23:44:28.093368 [ 428 ] {} Access(local_directory): Recovering lists in directory /var/lib/clickhouse/access/ 2025.10.23 23:44:28.994475 [ 428 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.10.23 23:44:42.474246 [ 432 ] {6719ef75-2e13-4a17-b7b0-b6a3ff5502f7} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE hits_v1; to attach existing table or CREATE TABLE hits_v1 ; to create new table or ATTACH TABLE hits_v1 FROM '/path/to/data/'
; to create new table and attach data. 2025.10.23 23:44:53.358273 [ 432 ] {da58cb3a-bb65-4758-9d9a-b237dcdf44e8} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE visits_v1; to attach existing table or CREATE TABLE visits_v1
; to create new table or ATTACH TABLE visits_v1 FROM '/path/to/data/'
; to create new table and attach data. 2025.10.23 23:45:02.258238 [ 1046 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled 2025.10.23 23:45:04.809162 [ 1299 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.10.23 23:45:04.809327 [ 1299 ] {} Context: Server was built with thread sanitizer. It will work slowly. 2025.10.23 23:45:04.938736 [ 1299 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.10.23 23:45:04.940014 [ 1299 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.10.23 23:45:08.546638 [ 1299 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.10.23 23:45:08.566200 [ 1299 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.10.23 23:45:08.566305 [ 1299 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.10.23 23:45:08.618576 [ 1903 ] {} RaftInstance: Election timeout, initiate leader election 2025.10.23 23:45:11.522073 [ 1299 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.10.23 23:46:38.873326 [ 1927 ] {} CgroupsMemoryUsageObserver: Exceeded hard memory limit (14.54 GiB) 2025.10.23 23:46:38.873961 [ 1927 ] {} CgroupsMemoryUsageObserver: Exceeded soft memory limit (13.77 GiB) 2025.10.23 23:46:39.337667 [ 2018 ] {} void DB::SystemLog::flushImpl(const std::vector &, uint64_t) [LogElement = DB::TextLogElement]: Failed to flush system log system.text_log with 55 entries up to offset 7752: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 16.09 GiB (attempt to allocate chunk of 4372149 bytes), maximum: 15.30 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fa371c5 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa3607e 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa35c1e 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:0: CurrentMemoryTracker::alloc(long) @ 0x000000000f9c356f 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000f9c0f7a 8. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000000fa99746 9. ./src/IO/BufferWithOwnMemory.h:0: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000000fac8a9b 10. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:0: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String) @ 0x000000000fac7b0f 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long) @ 0x000000000fc306b0 12. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007] const&>(std::__fs::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&) @ 0x00000000172b0766 13. ./build_docker/./src/Disks/DiskLocal.cpp:341: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x00000000172a6d2d 14. ./src/Disks/FakeDiskTransaction.h:75: DB::FakeDiskTransaction::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&, bool) @ 0x00000000172c8054 15. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:137: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000001988f22e 16. ./src/Storages/MergeTree/IDataPartStorage.h:0: DB::MergeTreePartition::store(DB::Block const&, DB::IDataPartStorage&, DB::MergeTreeDataPartChecksums&, DB::WriteSettings const&) const @ 0x0000000019bb27ac 17. ./build_docker/./src/Storages/MergeTree/MergeTreePartition.cpp:421: DB::MergeTreePartition::store(std::shared_ptr, std::shared_ptr, DB::IDataPartStorage&, DB::MergeTreeDataPartChecksums&) const @ 0x0000000019bb258b 18. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:267: DB::MergedBlockOutputStream::finalizePartOnDisk(std::shared_ptr const&, DB::MergeTreeDataPartChecksums&) @ 0x0000000019c92401 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x0000000019c90982 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000019ce0600 21. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000019cdbf52 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:118: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000019e9e55c 23. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7de8ed 24. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a6a6806 25. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6a6578 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a6a5e75 27. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 30. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a30e90c 31. ./build_docker/./src/Interpreters/SystemLog.cpp:0: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x0000000018043489 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:46:52.361723 [ 1303 ] {4db0d0f0-0482-474d-9449-443afb071c56} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.131875071 seconds, maximum: 60: While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (TIMEOUT_EXCEEDED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:33812) (in query: INSERT INTO test.hits_s3 SELECT * FROM datasets.hits_v1 SETTINGS enable_filesystem_cache_on_write_operations=0, max_insert_threads=16), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016e05586 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016e046a6 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000016e034ad 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303efd 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f067e952ac3 16. ? @ 0x00007f067e9e4850 2025.10.23 23:46:59.125071 [ 1303 ] {4db0d0f0-0482-474d-9449-443afb071c56} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.131875071 seconds, maximum: 60: While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016e05586 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016e046a6 5. ./build_docker/./src/QueryPipeline/ReadProgressCallback.cpp:0: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000016e034ad 6. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:62: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303efd 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f067e952ac3 16. ? @ 0x00007f067e9e4850 2025.10.23 23:48:08.894833 [ 1927 ] {} CgroupsMemoryUsageObserver: Exceeded hard memory limit (14.54 GiB) 2025.10.23 23:48:08.895398 [ 1927 ] {} CgroupsMemoryUsageObserver: Exceeded soft memory limit (13.77 GiB) 2025.10.23 23:48:18.993717 [ 1303 ] {6809e4cf-9ba0-492a-a191-8be82c38c68c} executeQuery: Code: 241. DB::Exception: Memory limit (for user) exceeded: would use 9.18 GiB (attempt to allocate chunk of 1064960 bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (while reading column ShareURL): (while reading from part store/78e/78ebf6a1-d987-4579-b3ec-00c1a087b1f3/201403_1_1_2/ in table datasets.hits_v1 (78ebf6a1-d987-4579-b3ec-00c1a087b1f3) located on disk __tmp_internal_262634248876485800814430204900764312493 of type web, from mark 20 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:48164) (in query: INSERT INTO test.hits SELECT * FROM datasets.hits_v1 SETTINGS enable_filesystem_cache_on_write_operations=0, max_insert_threads=16), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fa371c5 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa3607e 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa35c1e 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa35c1e 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:0: CurrentMemoryTracker::alloc(long) @ 0x000000000f9c356f 8. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000f9c0f7a 9. ./src/Common/PODArray.h:0: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000001702dee4 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f58c32 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x0000000019bfbc4a 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bfb20e 13. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 17. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a967e6a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 20. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f067e952ac3 31. ? @ 0x00007f067e9e4850 2025.10.23 23:48:25.325259 [ 1303 ] {6809e4cf-9ba0-492a-a191-8be82c38c68c} TCPHandler: Code: 241. DB::Exception: Memory limit (for user) exceeded: would use 9.18 GiB (attempt to allocate chunk of 1064960 bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (while reading column ShareURL): (while reading from part store/78e/78ebf6a1-d987-4579-b3ec-00c1a087b1f3/201403_1_1_2/ in table datasets.hits_v1 (78ebf6a1-d987-4579-b3ec-00c1a087b1f3) located on disk __tmp_internal_262634248876485800814430204900764312493 of type web, from mark 20 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fa371c5 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa3607e 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa35c1e 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa35c1e 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:0: CurrentMemoryTracker::alloc(long) @ 0x000000000f9c356f 8. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000f9c0f7a 9. ./src/Common/PODArray.h:0: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000001702dee4 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f58c32 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x0000000019bfbc4a 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bfb20e 13. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 17. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a967e6a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 20. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 21. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f067e952ac3 31. ? @ 0x00007f067e9e4850 2025.10.23 23:49:23.908313 [ 1927 ] {} CgroupsMemoryUsageObserver: Exceeded hard memory limit (14.54 GiB) 2025.10.23 23:49:23.908425 [ 1927 ] {} CgroupsMemoryUsageObserver: Exceeded soft memory limit (13.77 GiB) 2025.10.23 23:50:16.948007 [ 1303 ] {e401fbd1-cac9-45c7-bd40-414a12dabf7d} executeQuery: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.85 GiB (attempt to allocate chunk of 2621440 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45096) (in query: INSERT INTO test.visits SELECT * FROM datasets.visits_v1 SETTINGS enable_filesystem_cache_on_write_operations=0, max_insert_threads=16), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fa371c5 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa3607e 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa35c1e 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa35c1e 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa35c1e 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:0: CurrentMemoryTracker::alloc(long) @ 0x000000000f9c356f 9. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000f9c1440 10. void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000007b49b67 11. ./src/Common/PODArray.h:315: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000018e37fa0 12. DB::IColumn::insertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000007b3b963 13. ./src/Columns/ColumnArray.h:144: DB::ColumnArray::doInsertFrom(DB::IColumn const&, unsigned long) @ 0x0000000018ac13c2 14. DB::IColumn::insertFrom(DB::IColumn const&, unsigned long) @ 0x0000000007b2fdba 15. ./src/Processors/Merges/Algorithms/MergedData.h:58: DB::MergedData::insertRow(std::vector> const&, unsigned long, unsigned long) @ 0x000000001a7f8162 16. ./build_docker/./src/Processors/Merges/Algorithms/CollapsingSortedAlgorithm.cpp:103: DB::CollapsingSortedAlgorithm::insertRows() @ 0x000000001a7f59c3 17. ./build_docker/./src/Processors/Merges/Algorithms/CollapsingSortedAlgorithm.cpp:0: DB::CollapsingSortedAlgorithm::merge() @ 0x000000001a7f6507 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:426: DB::MergeTreeDataWriter::mergeBlock(DB::Block&&, DB::SortDescription, std::vector> const&, DB::PODArray, 63ul, 64ul>*&, DB::MergeTreeData::MergingParams const&) @ 0x0000000019cdb49e 19. ./contrib/llvm-project/libcxx/include/vector:1348: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000019cdd79f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000019cdbf52 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:118: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000019e9e55c 22. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7de8ed 23. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a6a6806 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6a6578 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a6a5e75 26. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 2025.10.23 23:50:23.462363 [ 1303 ] {e401fbd1-cac9-45c7-bd40-414a12dabf7d} TCPHandler: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.85 GiB (attempt to allocate chunk of 2621440 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, long&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fa371c5 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa3607e 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa35c1e 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa35c1e 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa35c1e 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:0: CurrentMemoryTracker::alloc(long) @ 0x000000000f9c356f 9. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000f9c1440 10. void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x0000000007b49b67 11. ./src/Common/PODArray.h:315: DB::ColumnVector::doInsertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000018e37fa0 12. DB::IColumn::insertRangeFrom(DB::IColumn const&, unsigned long, unsigned long) @ 0x0000000007b3b963 13. ./src/Columns/ColumnArray.h:144: DB::ColumnArray::doInsertFrom(DB::IColumn const&, unsigned long) @ 0x0000000018ac13c2 14. DB::IColumn::insertFrom(DB::IColumn const&, unsigned long) @ 0x0000000007b2fdba 15. ./src/Processors/Merges/Algorithms/MergedData.h:58: DB::MergedData::insertRow(std::vector> const&, unsigned long, unsigned long) @ 0x000000001a7f8162 16. ./build_docker/./src/Processors/Merges/Algorithms/CollapsingSortedAlgorithm.cpp:103: DB::CollapsingSortedAlgorithm::insertRows() @ 0x000000001a7f59c3 17. ./build_docker/./src/Processors/Merges/Algorithms/CollapsingSortedAlgorithm.cpp:0: DB::CollapsingSortedAlgorithm::merge() @ 0x000000001a7f6507 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:426: DB::MergeTreeDataWriter::mergeBlock(DB::Block&&, DB::SortDescription, std::vector> const&, DB::PODArray, 63ul, 64ul>*&, DB::MergeTreeData::MergingParams const&) @ 0x0000000019cdb49e 19. ./contrib/llvm-project/libcxx/include/vector:1348: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000019cdd79f 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000019cdbf52 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:118: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x0000000019e9e55c 22. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7de8ed 23. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a6a6806 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6a6578 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a6a5e75 26. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 2025.10.23 23:50:32.387207 [ 2683 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.10.23 23:50:32.387334 [ 2683 ] {} Context: Server was built with thread sanitizer. It will work slowly. 2025.10.23 23:50:32.461595 [ 2683 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.10.23 23:50:32.463087 [ 2683 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.10.23 23:50:32.464267 [ 2683 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.10.23 23:50:35.502585 [ 2683 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.10.23 23:50:35.523033 [ 2683 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.10.23 23:50:35.523135 [ 2683 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.10.23 23:50:35.575368 [ 3282 ] {} RaftInstance: Election timeout, initiate leader election 2025.10.23 23:50:40.008068 [ 2683 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.10.23 23:50:41.914881 [ 2687 ] {4f84c0d9-85d6-44c2-ae86-64cbe368a2da} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:39508) (in query: SELECT count() FROM system.build_options WHERE name = 'CXX_FLAGS' AND position('sanitize=address' IN value)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:50:41.915926 [ 2687 ] {4f84c0d9-85d6-44c2-ae86-64cbe368a2da} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:50:56.917075 [ 2689 ] {7898b08d-6c60-4371-b2e9-ca5db2406da2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53408) (in query: SELECT version(), arrayStringConcat(groupArray(value), ' ') FROM system.build_options WHERE name IN ('GIT_HASH', 'GIT_BRANCH') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f5511 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:50:56.918575 [ 2689 ] {7898b08d-6c60-4371-b2e9-ca5db2406da2} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f5511 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:50:58.107214 [ 3565 ] {257d8a99-6eaa-480b-8bf8-5ed98eff0b4c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53488) (in query: SELECT version(), arrayStringConcat(groupArray(value), ' ') FROM system.build_options WHERE name IN ('GIT_HASH', 'GIT_BRANCH') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2f303a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000182258bc 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.23 23:50:58.109054 [ 3565 ] {257d8a99-6eaa-480b-8bf8-5ed98eff0b4c} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2f303a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000182258bc 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:50:59.496752 [ 2687 ] {55a4e30d-0149-4ee1-8883-e3ae1f029ef2} executeQuery: Code: 44. DB::Exception: Cannot create table with column '_row_exists' for MergeTree engines because it is reserved for persistent virtual column. (ILLEGAL_COLUMN) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:38060) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (in query: CREATE TABLE t_row_exists (`a` int, `_row_exists` int) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 57869, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 56, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 532016803, compact_parts_max_granules_to_buffer = 62, compact_parts_merge_max_bytes_to_prefetch_part = 24860710, merge_max_block_size = 2773, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 4504301, concurrent_part_removal_threshold = 22, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 62535, primary_key_compress_block_size = 27404), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::validateVirtualColumns(DB::IStorage const&) @ 0x0000000017c47a8a 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c5423f 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:50:59.497903 [ 2687 ] {55a4e30d-0149-4ee1-8883-e3ae1f029ef2} TCPHandler: Code: 44. DB::Exception: Cannot create table with column '_row_exists' for MergeTree engines because it is reserved for persistent virtual column. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::validateVirtualColumns(DB::IStorage const&) @ 0x0000000017c47a8a 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c5423f 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:50:59.771922 [ 3576 ] {71565ce0-422c-4cc2-9d04-239eaa4e5226} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53140) (in query: SELECT version(), arrayStringConcat(groupArray(value), ' ') FROM system.build_options WHERE name IN ('GIT_HASH', 'GIT_BRANCH') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2f303a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000182258bc 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.23 23:50:59.773631 [ 3576 ] {71565ce0-422c-4cc2-9d04-239eaa4e5226} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2f303a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000182258bc 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:00.053790 [ 2687 ] {e775d2cf-b624-4c46-a0a6-2e6090304b02} executeQuery: Code: 44. DB::Exception: Cannot add column `_row_exists`: this column name is reserved for persistent virtual column. (ILLEGAL_COLUMN) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:38060) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (in query: alter table t_row_exists add column _row_exists int;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000190ee4e6 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c296ab 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:51:00.055049 [ 2687 ] {e775d2cf-b624-4c46-a0a6-2e6090304b02} TCPHandler: Code: 44. DB::Exception: Cannot add column `_row_exists`: this column name is reserved for persistent virtual column. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000190ee4e6 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c296ab 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:51:00.276265 [ 3565 ] {122d784a-bb0c-4483-9ba7-956e48fd3935} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53194) (in query: SELECT version(), arrayStringConcat(groupArray(value), ' ') FROM system.build_options WHERE name IN ('GIT_HASH', 'GIT_BRANCH') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2f303a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000182258bc 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.23 23:51:00.278690 [ 3565 ] {122d784a-bb0c-4483-9ba7-956e48fd3935} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2f303a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000182258bc 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:00.462242 [ 2687 ] {25a45ebc-8100-49ac-820d-ed5a2695519a} executeQuery: Code: 44. DB::Exception: Cannot rename to `_row_exists`: this column name is reserved for persistent virtual column. (ILLEGAL_COLUMN) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:38060) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (in query: alter table t_row_exists rename column b to _row_exists;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000190edd63 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c296ab 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:51:00.463615 [ 2687 ] {25a45ebc-8100-49ac-820d-ed5a2695519a} TCPHandler: Code: 44. DB::Exception: Cannot rename to `_row_exists`: this column name is reserved for persistent virtual column. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000190edd63 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c296ab 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:51:00.836008 [ 2687 ] {56e83e3b-e5fc-4bff-ac4a-997c7369bd14} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `_row_exists` to rename. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:38060) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (in query: alter table t_row_exists rename column _row_exists to c;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./build_docker/./src/Storages/AlterCommands.cpp:1557: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000190ee70f 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c296ab 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:51:00.836990 [ 2687 ] {56e83e3b-e5fc-4bff-ac4a-997c7369bd14} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `_row_exists` to rename. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./build_docker/./src/Storages/AlterCommands.cpp:1557: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000190ee70f 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c296ab 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:51:00.959321 [ 3565 ] {bacc3d65-1f80-4bae-95fa-90990d2e3952} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53206) (in query: SELECT version(), arrayStringConcat(groupArray(value), ' ') FROM system.build_options WHERE name IN ('GIT_HASH', 'GIT_BRANCH') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f5511 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:51:00.961463 [ 3565 ] {bacc3d65-1f80-4bae-95fa-90990d2e3952} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f5511 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:01.213728 [ 2687 ] {f675e347-a41d-433a-8d0e-3c1b1dbb6b95} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `_row_exists` to drop. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:38060) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (in query: alter table t_row_exists drop column _row_exists;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000190eea56 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c296ab 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:51:01.214533 [ 2687 ] {f675e347-a41d-433a-8d0e-3c1b1dbb6b95} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `_row_exists` to drop. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000190eea56 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c296ab 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:51:01.269049 [ 2687 ] {b14e835b-f176-458f-891a-68baec3c5236} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `unknown_column` to drop. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:38060) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (in query: alter table t_row_exists drop column unknown_column;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000190eea56 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c296ab 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:51:01.269737 [ 2687 ] {b14e835b-f176-458f-891a-68baec3c5236} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `unknown_column` to drop. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000190eea56 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c296ab 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:51:01.468454 [ 2687 ] {b84c67e7-3a00-44c2-9112-681bc630fbce} executeQuery: Code: 57. DB::Exception: Table test_1.t_row_exists already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:38060) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (in query: create table t_row_exists(a int, _row_exists int) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:51:01.469157 [ 2687 ] {b84c67e7-3a00-44c2-9112-681bc630fbce} TCPHandler: Code: 57. DB::Exception: Table test_1.t_row_exists already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:51:01.803317 [ 3576 ] {672c5567-f21d-4561-8c20-351517b9e6cf} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53282) (in query: SELECT version(), arrayStringConcat(groupArray(value), ' ') FROM system.build_options WHERE name IN ('GIT_HASH', 'GIT_BRANCH') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2f303a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000182258bc 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.23 23:51:01.805305 [ 3576 ] {672c5567-f21d-4561-8c20-351517b9e6cf} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2f303a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000182258bc 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:02.605421 [ 3683 ] {8b4b63ba-f0ba-4034-a661-241276b00ce6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53326) (in query: SELECT version(), arrayStringConcat(groupArray(value), ' ') FROM system.build_options WHERE name IN ('GIT_HASH', 'GIT_BRANCH') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2f303a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000182258bc 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.23 23:51:02.607827 [ 3683 ] {8b4b63ba-f0ba-4034-a661-241276b00ce6} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2f303a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000182258bc 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:03.873055 [ 2689 ] {85f0c9af-5c65-49fe-8ea3-5c0e439ab8bc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53538) (in query: SELECT version(), arrayStringConcat(groupArray(value), ' ') FROM system.build_options WHERE name IN ('GIT_HASH', 'GIT_BRANCH') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2f303a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000182258bc 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.23 23:51:03.875135 [ 2689 ] {85f0c9af-5c65-49fe-8ea3-5c0e439ab8bc} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2f303a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000182258bc 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:04.285322 [ 2689 ] {7857644c-c035-49a7-aa3c-c813e510c24a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53546) (in query: SELECT version(), arrayStringConcat(groupArray(value), ' ') FROM system.build_options WHERE name IN ('GIT_HASH', 'GIT_BRANCH') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f5511 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:51:04.287807 [ 2689 ] {7857644c-c035-49a7-aa3c-c813e510c24a} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f5511 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:05.727121 [ 3565 ] {d5ed4be1-dfd6-4faa-9914-12efa4b9ccb5} executeQuery: Code: 36. DB::Exception: Compound identifier 'lambda.nested' cannot be resolved as function. In scope WITH x -> (x + 1) AS lambda SELECT lambda.nested(1). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43664) (comment: 02385_analyzer_aliases_compound_expression.sql) (in query: WITH (x -> x + 1) AS lambda SELECT lambda.nested(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, char const*&&, String&&) @ 0x00000000174dc9ec 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b2c33 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b350f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bb5e1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.23 23:51:05.727980 [ 3565 ] {d5ed4be1-dfd6-4faa-9914-12efa4b9ccb5} TCPHandler: Code: 36. DB::Exception: Compound identifier 'lambda.nested' cannot be resolved as function. In scope WITH x -> (x + 1) AS lambda SELECT lambda.nested(1). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, char const*&&, String&&) @ 0x00000000174dc9ec 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b2c33 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b350f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bb5e1 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.23 23:51:06.395437 [ 3565 ] {a40b1486-937a-4de6-9a4e-0c9af7d2a081} executeQuery: Code: 36. DB::Exception: Compound identifier 't1.nested' cannot be resolved as table expression. In scope SELECT * FROM (SELECT 1) AS t1, t1.nested AS t2. (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43664) (comment: 02385_analyzer_aliases_compound_expression.sql) (in query: SELECT * FROM (SELECT 1) AS t1, t1.nested AS t2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, char const*&&, String&&) @ 0x00000000174dc9ec 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b2c33 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b350f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d4c62 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996bc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:51:06.396643 [ 3565 ] {a40b1486-937a-4de6-9a4e-0c9af7d2a081} TCPHandler: Code: 36. DB::Exception: Compound identifier 't1.nested' cannot be resolved as table expression. In scope SELECT * FROM (SELECT 1) AS t1, t1.nested AS t2. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, char const*&&, String&&) @ 0x00000000174dc9ec 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b2c33 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b350f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d4c62 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996bc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:51:06.409877 [ 3565 ] {0ae8a4b3-f611-49c4-9404-407561eefa18} executeQuery: Code: 36. DB::Exception: Compound identifier 't1.nested' cannot be resolved as table expression. In scope SELECT * FROM t1.nested AS t2, (SELECT 1) AS t1. (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43664) (comment: 02385_analyzer_aliases_compound_expression.sql) (in query: SELECT * FROM t1.nested AS t2, (SELECT 1) AS t1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, char const*&&, String&&) @ 0x00000000174dc9ec 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b2c33 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b350f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d4c62 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996bc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:51:06.411170 [ 3565 ] {0ae8a4b3-f611-49c4-9404-407561eefa18} TCPHandler: Code: 36. DB::Exception: Compound identifier 't1.nested' cannot be resolved as table expression. In scope SELECT * FROM t1.nested AS t2, (SELECT 1) AS t1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, char const*&&, String&&) @ 0x00000000174dc9ec 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b2c33 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b350f 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4221: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d4c62 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996bc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:51:07.758836 [ 3576 ] {31239771-bbea-4555-a2bf-95dabc64d242} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=723, jobs=707). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43786) (comment: 00149_quantiles_timing_distributed.sql) (in query: SELECT sum(cityHash64(*)) FROM (SELECT CounterID, quantileTiming(0.5)(SendTiming), count() FROM remote('127.0.0.{1,2,3,4,5,6,7,8,9,10}', test.hits) WHERE SendTiming != -1 GROUP BY CounterID) SETTINGS optimize_aggregation_in_order = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:51:07.761365 [ 3576 ] {31239771-bbea-4555-a2bf-95dabc64d242} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=723, jobs=707). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:51:10.273685 [ 4059 ] {e6f20796-f813-4837-8db2-33f59e704b47} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:51886) (comment: 01825_type_json_empty_string.sql) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:51:10.491980 [ 4059 ] {e6f20796-f813-4837-8db2-33f59e704b47} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:51:12.205407 [ 2689 ] {c396a46f-5cb4-4b52-aa75-c07f0e7bbfb8} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50584) (comment: 00180_no_seek_avoiding_when_reading_from_cache.sh) (in query: DROP DATABASE IF EXISTS test_23as4y6u ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:51:12.207257 [ 2689 ] {c396a46f-5cb4-4b52-aa75-c07f0e7bbfb8} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:16.567870 [ 3576 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database no_such_database_could_exist does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a157 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:16.574739 [ 4108 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database no_such_database_could_exist does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a157 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:16.659681 [ 2687 ] {797646ec-08ed-4008-bc44-63af9951abb3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43648) (comment: 02796_projection_date_filter_on_view.sql) (in query: -- segmentation fault (filter on dt_close column) SELECT dt_close, close FROM fx_5m where symbol = 'EURUSD' and dt_close between '2022-12-11' and '2022-12-13' order by dt_close format Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:51:16.663492 [ 2687 ] {797646ec-08ed-4008-bc44-63af9951abb3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:51:17.637570 [ 3565 ] {6400d6e4-6495-448a-939f-3b433f83712f} executeQuery: Code: 57. DB::Exception: Table test_1.mutation_table already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:52242) (comment: 01475_mutation_with_if.sql) (in query: CREATE TABLE mutation_table (`dt` Nullable(Date), `name` Nullable(String)) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 20225, min_bytes_for_wide_part = 987037268, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 53, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 483153863, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 1490477, merge_max_block_size = 1902, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 4917032244, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 2515658, concurrent_part_removal_threshold = 99, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 60600, primary_key_compress_block_size = 62330), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:51:17.640028 [ 3565 ] {6400d6e4-6495-448a-939f-3b433f83712f} TCPHandler: Code: 57. DB::Exception: Table test_1.mutation_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:51:18.058313 [ 4106 ] {a1b6026a-4884-4bf8-a986-ec7e7e789466} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:52136) (comment: 00165_jit_aggregate_functions.sql) (in query: SELECT min(WatchID) AS min_watch_id, max(WatchID), sum(WatchID), avg(WatchID), avgWeighted(WatchID, CounterID), count(WatchID), groupBitOr(WatchID), groupBitAnd(WatchID), groupBitXor(WatchID) FROM test.hits ORDER BY min_watch_id DESC LIMIT 20;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:51:18.060025 [ 4106 ] {a1b6026a-4884-4bf8-a986-ec7e7e789466} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:51:18.192315 [ 3576 ] {19df1d20-871a-4b32-83e5-9f447e9cd11c} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:52228) (comment: 03095_window_functions_qualify.sql) (in query: SELECT number % toUInt256(2) AS key, count() FROM numbers(10) GROUP BY key WITH CUBE WITH TOTALS QUALIFY key = toNullable(toNullable(0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5315: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749be44 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 11. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.23 23:51:18.193837 [ 3576 ] {19df1d20-871a-4b32-83e5-9f447e9cd11c} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5315: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749be44 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 11. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.23 23:51:18.206578 [ 3576 ] {02603da3-bf37-480a-840f-5c789421e7f7} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:52228) (comment: 03095_window_functions_qualify.sql) (in query: SELECT number % 2 AS key, count(materialize(5)) IGNORE NULLS FROM numbers(10) WHERE toLowCardinality(toLowCardinality(materialize(2))) GROUP BY key WITH CUBE WITH TOTALS QUALIFY key = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5315: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749be44 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 11. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.23 23:51:18.210334 [ 3576 ] {02603da3-bf37-480a-840f-5c789421e7f7} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5315: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749be44 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 11. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.23 23:51:18.222405 [ 3576 ] {e4d05d00-1393-49f9-b71c-19ad5872097b} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:52228) (comment: 03095_window_functions_qualify.sql) (in query: SELECT 4, count(4) IGNORE NULLS, number % 2 AS key FROM numbers(10) GROUP BY key WITH ROLLUP WITH TOTALS QUALIFY key = materialize(0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5315: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749be44 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 11. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.23 23:51:18.223465 [ 3576 ] {e4d05d00-1393-49f9-b71c-19ad5872097b} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5315: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749be44 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 11. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.23 23:51:18.236798 [ 3576 ] {fc09b07e-4eab-49de-869e-0e46a3a3cbe6} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:52228) (comment: 03095_window_functions_qualify.sql) (in query: SELECT 3, number % toLowCardinality(2) AS key, count() IGNORE NULLS FROM numbers(10) GROUP BY key WITH ROLLUP WITH TOTALS QUALIFY key = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5315: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749be44 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 11. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.23 23:51:18.237848 [ 3576 ] {fc09b07e-4eab-49de-869e-0e46a3a3cbe6} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5315: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749be44 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 7. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 8. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 11. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.23 23:51:20.269362 [ 4108 ] {aad0ee3f-be85-4d17-b398-69fd449fa9c2} executeQuery: Code: 36. DB::Exception: The disk `02963_custom_disk` is already configured as a custom disk in another table. It can't be redefined with different settings.: While processing disk(name = '02963_custom_disk', type = object_storage, object_storage_type = local_blob_storage, path = './02963_test2/'). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57592) (comment: 02963_test_flexible_disk_configuration.sql) (in query: CREATE TABLE test (`a` Int32) ENGINE = MergeTree ORDER BY tuple() SETTINGS disk = disk(name = '02963_custom_disk', type = object_storage, object_storage_type = local_blob_storage, path = './02963_test2/'), index_granularity = 49119, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.17597107589244843, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 46596187, compact_parts_max_granules_to_buffer = 29, compact_parts_merge_max_bytes_to_prefetch_part = 33216495, merge_max_block_size = 20873, old_parts_lifetime = 363., prefer_fetch_merged_part_size_threshold = 9052167431, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 97, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 19470875, concurrent_part_removal_threshold = 86, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 27261, primary_key_compress_block_size = 54601), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Disks/DiskFomAST.cpp:0: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000019c78053 5. ./build_docker/./src/Disks/DiskFomAST.cpp:0: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000019c7945c 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000019c7918d 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::DiskFomAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000019c784f9 8. ./contrib/llvm-project/libcxx/include/string:1570: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000019c30de4 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e48c62 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 11. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:51:20.271349 [ 4108 ] {aad0ee3f-be85-4d17-b398-69fd449fa9c2} TCPHandler: Code: 36. DB::Exception: The disk `02963_custom_disk` is already configured as a custom disk in another table. It can't be redefined with different settings.: While processing disk(name = '02963_custom_disk', type = object_storage, object_storage_type = local_blob_storage, path = './02963_test2/'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Disks/DiskFomAST.cpp:0: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000019c78053 5. ./build_docker/./src/Disks/DiskFomAST.cpp:0: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000019c7945c 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000019c7918d 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::DiskFomAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000019c784f9 8. ./contrib/llvm-project/libcxx/include/string:1570: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000019c30de4 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e48c62 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 11. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:51:20.893845 [ 4108 ] {4364e12f-5304-4775-aab5-505abb588afa} executeQuery: Code: 36. DB::Exception: Disk function `disk(name = '02963_custom_disk')` must have other arguments apart from `name`, which describe disk configuration. Invalid disk description.: While processing disk(name = '02963_custom_disk'). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57592) (comment: 02963_test_flexible_disk_configuration.sql) (in query: CREATE TABLE test (`a` Int32) ENGINE = MergeTree ORDER BY tuple() SETTINGS disk = disk(name = '02963_custom_disk'), index_granularity = 49119, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.17597107589244843, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 46596187, compact_parts_max_granules_to_buffer = 29, compact_parts_merge_max_bytes_to_prefetch_part = 33216495, merge_max_block_size = 20873, old_parts_lifetime = 363., prefer_fetch_merged_part_size_threshold = 9052167431, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 97, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 19470875, concurrent_part_removal_threshold = 86, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 27261, primary_key_compress_block_size = 54601), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Disks/DiskFomAST.cpp:0: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000019c78111 5. ./build_docker/./src/Disks/DiskFomAST.cpp:0: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000019c7945c 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000019c7918d 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::DiskFomAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000019c784f9 8. ./contrib/llvm-project/libcxx/include/string:1570: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000019c30de4 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e48c62 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 11. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:51:20.895048 [ 4108 ] {4364e12f-5304-4775-aab5-505abb588afa} TCPHandler: Code: 36. DB::Exception: Disk function `disk(name = '02963_custom_disk')` must have other arguments apart from `name`, which describe disk configuration. Invalid disk description.: While processing disk(name = '02963_custom_disk'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Disks/DiskFomAST.cpp:0: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000019c78111 5. ./build_docker/./src/Disks/DiskFomAST.cpp:0: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000019c7945c 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000019c7918d 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::DiskFomAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000019c784f9 8. ./contrib/llvm-project/libcxx/include/string:1570: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000019c30de4 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e48c62 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 11. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:51:21.290193 [ 4108 ] {035d1eb9-7730-405a-ba10-5eac6fac85b8} executeQuery: Code: 36. DB::Exception: Disk name `02963_custom_disk` is a custom disk that is used in other table. That disk could not be used by a reference by other tables. The custom disk should be fully specified with a disk function. (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57592) (comment: 02963_test_flexible_disk_configuration.sql) (in query: CREATE TABLE test (`a` Int32) ENGINE = MergeTree ORDER BY tuple() SETTINGS disk = '02963_custom_disk', index_granularity = 49119, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.17597107589244843, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 46596187, compact_parts_max_granules_to_buffer = 29, compact_parts_merge_max_bytes_to_prefetch_part = 33216495, merge_max_block_size = 20873, old_parts_lifetime = 363., prefer_fetch_merged_part_size_threshold = 9052167431, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 97, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 19470875, concurrent_part_removal_threshold = 86, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 27261, primary_key_compress_block_size = 54601), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Disks/DiskFomAST.cpp:143: DB::DiskFomAST::ensureDiskIsNotCustom(String const&, std::shared_ptr) @ 0x0000000019c7890e 5. ./src/Core/BaseSettings.h:82: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000019c30ef5 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e48c62 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.23 23:51:21.291560 [ 4108 ] {035d1eb9-7730-405a-ba10-5eac6fac85b8} TCPHandler: Code: 36. DB::Exception: Disk name `02963_custom_disk` is a custom disk that is used in other table. That disk could not be used by a reference by other tables. The custom disk should be fully specified with a disk function. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Disks/DiskFomAST.cpp:143: DB::DiskFomAST::ensureDiskIsNotCustom(String const&, std::shared_ptr) @ 0x0000000019c7890e 5. ./src/Core/BaseSettings.h:82: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000019c30ef5 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e48c62 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.23 23:51:21.392451 [ 3565 ] {8f00d650-16c7-4b27-9bf9-d5b2b987737d} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:52280) (comment: 00126_buffer.sql) (in query: DROP TABLE buffer_00126;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1e9f1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c766aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c74615 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c739c9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:51:21.394206 [ 3565 ] {8f00d650-16c7-4b27-9bf9-d5b2b987737d} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1e9f1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c766aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c74615 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c739c9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:51:21.401696 [ 4108 ] {93d5692c-fc5f-436f-8029-cdc2bac4abc7} executeQuery: Code: 36. DB::Exception: Disk function `disk(name = 's3_disk_02963')` must have other arguments apart from `name`, which describe disk configuration. Invalid disk description.: While processing disk(name = 's3_disk_02963'). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57592) (comment: 02963_test_flexible_disk_configuration.sql) (in query: CREATE TABLE test (`a` Int32) ENGINE = MergeTree ORDER BY tuple() SETTINGS disk = disk(name = 's3_disk_02963'), index_granularity = 49119, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.17597107589244843, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 46596187, compact_parts_max_granules_to_buffer = 29, compact_parts_merge_max_bytes_to_prefetch_part = 33216495, merge_max_block_size = 20873, old_parts_lifetime = 363., prefer_fetch_merged_part_size_threshold = 9052167431, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 97, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 19470875, concurrent_part_removal_threshold = 86, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 27261, primary_key_compress_block_size = 54601), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Disks/DiskFomAST.cpp:0: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000019c78111 5. ./build_docker/./src/Disks/DiskFomAST.cpp:0: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000019c7945c 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000019c7918d 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::DiskFomAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000019c784f9 8. ./contrib/llvm-project/libcxx/include/string:1570: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000019c30de4 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e48c62 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 11. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:51:21.403001 [ 4108 ] {93d5692c-fc5f-436f-8029-cdc2bac4abc7} TCPHandler: Code: 36. DB::Exception: Disk function `disk(name = 's3_disk_02963')` must have other arguments apart from `name`, which describe disk configuration. Invalid disk description.: While processing disk(name = 's3_disk_02963'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Disks/DiskFomAST.cpp:0: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x0000000019c78111 5. ./build_docker/./src/Disks/DiskFomAST.cpp:0: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x0000000019c7945c 6. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000019c7918d 7. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::DiskFomAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000019c784f9 8. ./contrib/llvm-project/libcxx/include/string:1570: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x0000000019c30de4 9. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e48c62 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 11. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:51:21.496228 [ 4108 ] {bdba3ce2-0ad3-4a19-9ec9-e22f7a271e8c} executeQuery: Code: 57. DB::Exception: Table test_13.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57592) (comment: 02963_test_flexible_disk_configuration.sql) (in query: CREATE TABLE test (`a` Int32) ENGINE = MergeTree ORDER BY tuple() SETTINGS disk = disk(name = 's3_disk_02963', type = object_storage, object_storage_type = local_blob_storage, path = './02963_test2/'), index_granularity = 49119, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.17597107589244843, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 46596187, compact_parts_max_granules_to_buffer = 29, compact_parts_merge_max_bytes_to_prefetch_part = 33216495, merge_max_block_size = 20873, old_parts_lifetime = 363., prefer_fetch_merged_part_size_threshold = 9052167431, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 97, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 19470875, concurrent_part_removal_threshold = 86, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 27261, primary_key_compress_block_size = 54601), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:51:21.497568 [ 4108 ] {bdba3ce2-0ad3-4a19-9ec9-e22f7a271e8c} TCPHandler: Code: 57. DB::Exception: Table test_13.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:51:22.198588 [ 3565 ] {58495c0a-6bbd-42a2-a697-dec715d70d90} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57692) (comment: 00172_early_constant_folding.sql) (in query: EXPLAIN PIPELINE SELECT count(JavaEnable) FROM test.hits WHERE WatchID = 1 OR Title = 'next' OR URL = 'prev' OR URL = '???' OR 1 SETTINGS enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x0000000017e4e0a9 9. ./src/Interpreters/InterpreterSetQuery.h:14: DB::applySettingsFromSelectWithUnion(DB::ASTSelectWithUnionQuery const&, std::shared_ptr) @ 0x0000000017e4eb63 10. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:65: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000017e4e49e 11. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:72: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000017e4e84c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821d862 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.23 23:51:22.220555 [ 3565 ] {58495c0a-6bbd-42a2-a697-dec715d70d90} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x0000000017e4e0a9 9. ./src/Interpreters/InterpreterSetQuery.h:14: DB::applySettingsFromSelectWithUnion(DB::ASTSelectWithUnionQuery const&, std::shared_ptr) @ 0x0000000017e4eb63 10. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:65: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000017e4e49e 11. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:72: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000017e4e84c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821d862 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.23 23:51:22.237575 [ 4108 ] {9a4e9e05-b6f8-4f24-8be4-0273844fe998} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 0.00 B (attempt to allocate chunk of 0 bytes), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57696) (comment: 02845_group_by_constant_keys.sql) (in query: select count(number), 1 AS k1, 2 as k2, 3 as k3 from numbers_mt(10000000) group by k1, k2, k3 settings optimize_group_by_constant_keys=1, enable_software_prefetch_in_aggregation=0, compile_aggregate_expressions=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000000fa3705c 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa361e0 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa35c1e 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:85: CurrentMemoryTracker::check() @ 0x000000000f9c34a8 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1710: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x00000000177410c3 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1497: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000001774dee5 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000001a671b9e 10. ./contrib/llvm-project/libcxx/include/vector:438: DB::AggregatingTransform::work() @ 0x000000001a66dd53 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:51:22.239648 [ 4108 ] {9a4e9e05-b6f8-4f24-8be4-0273844fe998} TCPHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 0.00 B (attempt to allocate chunk of 0 bytes), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000000fa3705c 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa361e0 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa35c1e 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:85: CurrentMemoryTracker::check() @ 0x000000000f9c34a8 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1710: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x00000000177410c3 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1497: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000001774dee5 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000001a671b9e 10. ./contrib/llvm-project/libcxx/include/vector:438: DB::AggregatingTransform::work() @ 0x000000001a66dd53 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:51:22.607026 [ 3873 ] {f265a926-6d55-4ab8-8915-3461e6f50f30} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57704) (comment: 02941_variant_type_alters.sh) (in query: select x, y, v, v.String, v.UInt64, v.Date from test order by x), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c63e3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.23 23:51:22.609485 [ 3873 ] {f265a926-6d55-4ab8-8915-3461e6f50f30} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c63e3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.23 23:51:23.137103 [ 3683 ] {36ca79e1-9203-4c7f-850d-cf57e67ee6b0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=730, jobs=712). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57700) (comment: 00398_url_functions.gen.sql) (in query: SELECT domainRFC('http://paul@www.example.com:80/') AS Host;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:51:23.137866 [ 3683 ] {36ca79e1-9203-4c7f-850d-cf57e67ee6b0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=730, jobs=712). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:51:23.321173 [ 3321 ] {54a28376-ecf2-4d7e-a452-b09dcc5bb01b::all_8_8_0_9} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:23.591791 [ 3321 ] {54a28376-ecf2-4d7e-a452-b09dcc5bb01b::all_8_8_0_9} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./contrib/llvm-project/libcxx/include/optional:260: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000019c07767 17. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8f5f22 18. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9210b9 19. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1312: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x0000000017ebad9e 20. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::execute() @ 0x0000000017ebe95b 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MutateTask::prepare() @ 0x0000000019cae25b 22. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000019ca8475 23. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:0: DB::MutatePlainMergeTreeTask::executeStep() @ 0x0000000019ea4e1b 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:23.664100 [ 3873 ] {6e893f6b-9f46-4517-8664-e564ad55df91} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57708) (comment: 01528_setting_aggregate_functions_null_for_empty.sql) (in query: SELECT sum(n) FROM defaults;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:51:23.665475 [ 3873 ] {6e893f6b-9f46-4517-8664-e564ad55df91} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:51:23.673828 [ 3875 ] {03ac0c0a-d1e2-4212-b954-67c19b0c99a3} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_9.txt' with part 'all_8_8_0' reason: 'Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57734) (comment: 02941_variant_type_alters.sh) (in query: alter table test modify column y Variant(UInt64, String) settings mutations_sync=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000019ba6454 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000019ba635c 5. ./src/Common/SharedLockGuard.h:19: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000019e594c0 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000019e559ee 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2973f 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:51:23.675215 [ 3875 ] {03ac0c0a-d1e2-4212-b954-67c19b0c99a3} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_9.txt' with part 'all_8_8_0' reason: 'Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000019ba6454 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000019ba635c 5. ./src/Common/SharedLockGuard.h:19: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000019e594c0 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x0000000019e559ee 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2973f 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:51:24.504227 [ 3873 ] {e4e2ef4f-73d0-4123-a1de-3ce9af01b811} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57804) (comment: 02461_welch_t_test_fuzz.sql) (in query: SELECT roundBankers(studentTTest(left, right).2, 6) from welch_ttest__fuzz_7;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:51:24.505985 [ 3873 ] {e4e2ef4f-73d0-4123-a1de-3ce9af01b811} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:51:25.627419 [ 3683 ] {d2ce70d4-0f79-4a51-b647-e76dce114f37} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57882) (comment: 02011_dictionary_empty_attribute_list.sql) (in query: DROP DICTIONARY test_dictionary;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c771c0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c74615 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c739c9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:51:25.628441 [ 3683 ] {d2ce70d4-0f79-4a51-b647-e76dce114f37} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c771c0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c74615 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c739c9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:51:26.525285 [ 3683 ] {f4982d0b-95e7-46e4-83ae-08ebddb87cff} executeQuery: Code: 57. DB::Exception: Table test_9.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57978) (comment: 00161_parallel_parsing_with_names.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:51:26.526061 [ 3683 ] {f4982d0b-95e7-46e4-83ae-08ebddb87cff} TCPHandler: Code: 57. DB::Exception: Table test_9.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:51:26.532006 [ 4019 ] {a69c142c-f6f1-4155-b9a9-bfb07db98f03} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57964) (comment: 00022_merge_prewhere.sql) (in query: DROP TABLE test.merge_hits;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1e9f1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c766aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c74615 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c739c9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:51:26.532792 [ 4019 ] {a69c142c-f6f1-4155-b9a9-bfb07db98f03} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1e9f1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c766aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c74615 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c739c9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:51:27.834529 [ 3683 ] {0ffa80d4-ae19-49af-9707-72accf514cf7} executeQuery: Code: 57. DB::Exception: Table test_ruc8r24l.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:58080) (comment: 00161_parallel_parsing_with_names.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:51:27.840326 [ 3683 ] {0ffa80d4-ae19-49af-9707-72accf514cf7} TCPHandler: Code: 57. DB::Exception: Table test_ruc8r24l.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:51:29.031764 [ 4060 ] {7a70b65d-86a3-4f71-b93b-341ed8774fcc} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e9. Expected to read decimal with scale 0 and precision 9: In scope SELECT '-1E9-1E9-1E9-1E9' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:58172) (comment: 01425_decimal_parse_big_negative_exponent.sql) (in query: SELECT '-1E9-1E9-1E9-1E9' AS x, toDecimal32(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x0000000016ee4a5c 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000016ee2224 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000016f7a804 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000007a400e3 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000007a3d3d6 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007a30764 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 27. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 2025.10.23 23:51:29.033089 [ 4060 ] {7a70b65d-86a3-4f71-b93b-341ed8774fcc} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e9. Expected to read decimal with scale 0 and precision 9: In scope SELECT '-1E9-1E9-1E9-1E9' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x0000000016ee4a5c 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000016ee2224 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000016f7a804 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000007a400e3 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000007a3d3d6 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007a30764 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 27. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 2025.10.23 23:51:29.064733 [ 3683 ] {e5ca8992-db76-4db8-a3a9-faaa29261c3e} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `non_existing_column` to drop. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:44668) (comment: 01079_bad_alters_zookeeper_long.sh) (in query: ALTER TABLE table_for_bad_alters MODIFY COLUMN value1 UInt32, DROP COLUMN non_existing_column), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000190eea56 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c296ab 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:51:29.066240 [ 3683 ] {e5ca8992-db76-4db8-a3a9-faaa29261c3e} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `non_existing_column` to drop. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000190eea56 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c296ab 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:51:29.082266 [ 4060 ] {74a837b9-6e9b-4a34-a61e-b3151ced9255} executeQuery: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e9. Expected to read decimal with scale 0 and precision 9: In scope SELECT '-1E9' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:58172) (comment: 01425_decimal_parse_big_negative_exponent.sql) (in query: SELECT '-1E9' AS x, toDecimal32(x, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x0000000016ee4a5c 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000016ee2224 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000016f7a804 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000007a400e3 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000007a3d3d6 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007a30764 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 27. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 2025.10.23 23:51:29.083629 [ 4060 ] {74a837b9-6e9b-4a34-a61e-b3151ced9255} TCPHandler: Code: 69. DB::Exception: Decimal value is too big: 1 digits were read: -1e9. Expected to read decimal with scale 0 and precision 9: In scope SELECT '-1E9' AS x, toDecimal32(x, 0). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception&, int&, unsigned int&, unsigned int&>(int, FormatStringHelperImpl::type, std::type_identity&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, unsigned int&, DB::Decimal&, int&, unsigned int&, unsigned int&) @ 0x0000000016ee4a5c 4. ./src/IO/readDecimalText.h:172: void DB::readDecimalText, void>(DB::ReadBuffer&, DB::Decimal&, unsigned int, unsigned int&, bool) @ 0x0000000016ee2224 5. ./build_docker/./src/DataTypes/Serializations/SerializationDecimal.cpp:48: DB::SerializationDecimal>::readText(DB::Decimal&, DB::ReadBuffer&, unsigned int, unsigned int, bool) @ 0x0000000016f7a804 6. COW::immutable_ptr DB::(anonymous namespace)::ConvertThroughParsing>, DB::(anonymous namespace)::NameToDecimal32, (DB::(anonymous namespace)::ConvertFromStringExceptionMode)0, (DB::(anonymous namespace)::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000007a400e3 7. bool DB::callOnIndexAndDataType>, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x0000000007a3d3d6 8. DB::(anonymous namespace)::FunctionConvert>, DB::(anonymous namespace)::NameToDecimal32, DB::(anonymous namespace)::UnknownMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007a30764 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 27. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 2025.10.23 23:51:29.259629 [ 4060 ] {cf752617-1d2f-4893-815b-402c16266eab} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=746, jobs=712). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:58172) (comment: 01425_decimal_parse_big_negative_exponent.sql) (in query: SELECT '1E-9' AS x, toDecimal32(x, 9);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:51:29.260056 [ 4060 ] {cf752617-1d2f-4893-815b-402c16266eab} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=746, jobs=712). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:51:30.507885 [ 4059 ] {6b2768d5-34cd-40db-9f28-949274afb020} executeQuery: Code: 57. DB::Exception: Table test_ruc8r24l.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:44810) (comment: 00161_parallel_parsing_with_names.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:51:30.509470 [ 4059 ] {6b2768d5-34cd-40db-9f28-949274afb020} TCPHandler: Code: 57. DB::Exception: Table test_ruc8r24l.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:51:30.817703 [ 3321 ] {} 11b526bb-bffd-4b55-bfe0-1bf28b690b08::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value2 :: 2, 'UInt32' :: 3) -> _CAST(value2, 'UInt32') UInt32 : 4': (while reading from part /var/lib/clickhouse/store/11b/11b526bb-bffd-4b55-bfe0-1bf28b690b08/all_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000776fec0 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000077d40ca 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000077ca444 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007635b7e 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000779893f 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007765447 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087152b7 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x00000000176c9952 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000182425a5 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:0: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000019bd58ae 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: DB::MergeTreeSequentialSource::generate() @ 0x0000000019c03577 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2e13d5 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a30a201 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000019ca4616 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000019ccfe5d 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000019cca2f4 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000019ca84bb (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:30.819423 [ 3321 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {11b526bb-bffd-4b55-bfe0-1bf28b690b08::all_0_0_0_1}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value2 :: 2, 'UInt32' :: 3) -> _CAST(value2, 'UInt32') UInt32 : 4': (while reading from part /var/lib/clickhouse/store/11b/11b526bb-bffd-4b55-bfe0-1bf28b690b08/all_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000776fec0 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000077d40ca 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000077ca444 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007635b7e 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000779893f 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007765447 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087152b7 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x00000000176c9952 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000182425a5 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:0: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000019bd58ae 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: DB::MergeTreeSequentialSource::generate() @ 0x0000000019c03577 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2e13d5 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a30a201 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000019ca4616 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000019ccfe5d 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000019cca2f4 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000019ca84bb (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:31.216221 [ 3309 ] {} 11b526bb-bffd-4b55-bfe0-1bf28b690b08::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value2 :: 2, 'UInt32' :: 3) -> _CAST(value2, 'UInt32') UInt32 : 4': (while reading from part /var/lib/clickhouse/store/11b/11b526bb-bffd-4b55-bfe0-1bf28b690b08/all_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000776fec0 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000077d40ca 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000077ca444 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007635b7e 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000779893f 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007765447 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087152b7 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x00000000176c9952 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000182425a5 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:0: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000019bd58ae 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: DB::MergeTreeSequentialSource::generate() @ 0x0000000019c03577 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2e13d5 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a30a201 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000019ca4616 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000019ccfe5d 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000019cca2f4 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000019ca84bb (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:31.217293 [ 3309 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {11b526bb-bffd-4b55-bfe0-1bf28b690b08::all_0_0_0_1}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value2 :: 2, 'UInt32' :: 3) -> _CAST(value2, 'UInt32') UInt32 : 4': (while reading from part /var/lib/clickhouse/store/11b/11b526bb-bffd-4b55-bfe0-1bf28b690b08/all_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000776fec0 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000077d40ca 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000077ca444 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007635b7e 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000779893f 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007765447 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087152b7 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x00000000176c9952 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000182425a5 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:0: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000019bd58ae 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: DB::MergeTreeSequentialSource::generate() @ 0x0000000019c03577 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2e13d5 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a30a201 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000019ca4616 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000019ccfe5d 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000019cca2f4 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000019ca84bb (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:31.261017 [ 4096 ] {a68d6d8c-2ac2-49b2-96ed-7d8d3f2bc19a} executeQuery: Code: 57. DB::Exception: Table test_9.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:44884) (comment: 00161_parallel_parsing_with_names.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:51:31.262739 [ 4096 ] {a68d6d8c-2ac2-49b2-96ed-7d8d3f2bc19a} TCPHandler: Code: 57. DB::Exception: Table test_9.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:51:31.584212 [ 3314 ] {} 11b526bb-bffd-4b55-bfe0-1bf28b690b08::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value2 :: 2, 'UInt32' :: 3) -> _CAST(value2, 'UInt32') UInt32 : 4': (while reading from part /var/lib/clickhouse/store/11b/11b526bb-bffd-4b55-bfe0-1bf28b690b08/all_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000776fec0 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000077d40ca 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000077ca444 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007635b7e 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000779893f 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007765447 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087152b7 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x00000000176c9952 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000182425a5 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:0: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000019bd58ae 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: DB::MergeTreeSequentialSource::generate() @ 0x0000000019c03577 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2e13d5 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a30a201 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000019ca4616 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000019ccfe5d 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000019cca2f4 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000019ca84bb (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:31.585318 [ 3314 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {11b526bb-bffd-4b55-bfe0-1bf28b690b08::all_0_0_0_1}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value2 :: 2, 'UInt32' :: 3) -> _CAST(value2, 'UInt32') UInt32 : 4': (while reading from part /var/lib/clickhouse/store/11b/11b526bb-bffd-4b55-bfe0-1bf28b690b08/all_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000776fec0 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000077d40ca 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000077ca444 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007635b7e 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000779893f 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007765447 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087152b7 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x00000000176c9952 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000182425a5 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:0: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000019bd58ae 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: DB::MergeTreeSequentialSource::generate() @ 0x0000000019c03577 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2e13d5 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a30a201 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000019ca4616 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000019ccfe5d 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000019cca2f4 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000019ca84bb (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:32.226285 [ 3322 ] {} 11b526bb-bffd-4b55-bfe0-1bf28b690b08::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value2 :: 2, 'UInt32' :: 3) -> _CAST(value2, 'UInt32') UInt32 : 4': (while reading from part /var/lib/clickhouse/store/11b/11b526bb-bffd-4b55-bfe0-1bf28b690b08/all_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000776fec0 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000077d40ca 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000077ca444 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007635b7e 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000779893f 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007765447 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087152b7 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x00000000176c9952 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000182425a5 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:0: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000019bd58ae 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: DB::MergeTreeSequentialSource::generate() @ 0x0000000019c03577 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2e13d5 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a30a201 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000019ca4616 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000019ccfe5d 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000019cca2f4 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000019ca84bb (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:32.227485 [ 3322 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {11b526bb-bffd-4b55-bfe0-1bf28b690b08::all_0_0_0_1}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value2 :: 2, 'UInt32' :: 3) -> _CAST(value2, 'UInt32') UInt32 : 4': (while reading from part /var/lib/clickhouse/store/11b/11b526bb-bffd-4b55-bfe0-1bf28b690b08/all_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000776fec0 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000077d40ca 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000077ca444 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007635b7e 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000779893f 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007765447 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087152b7 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x00000000176c9952 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000182425a5 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:0: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000019bd58ae 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:0: DB::MergeTreeSequentialSource::generate() @ 0x0000000019c03577 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2e13d5 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a30a201 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000019ca4616 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000019ccfe5d 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000019cca2f4 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000019ca84bb (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:32.335689 [ 3314 ] {} test_13.table_for_bad_alters (ReplicatedMergeTreeQueue): There are no mutations for partition ID all (trying to mutate part all_0_0_0 to 1) 2025.10.23 23:51:32.989967 [ 4059 ] {b066dce5-773a-4e09-bcd1-0bc8df8de86f} executeQuery: Code: 57. DB::Exception: Table test_ruc8r24l.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45026) (comment: 00161_parallel_parsing_with_names.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:51:32.990994 [ 4059 ] {b066dce5-773a-4e09-bcd1-0bc8df8de86f} TCPHandler: Code: 57. DB::Exception: Table test_ruc8r24l.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:51:33.853363 [ 5099 ] {} ExternalDictionaries: Could not update cache dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)', next update is scheduled at 2025-10-23 23:51:38: Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.view_for_dict' in scope SELECT key_column, second_column, third_column FROM ordinary_db.view_for_dict WHERE key_column IN (888, 311). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d594c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996bc 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000000fe64c6e 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000000fe650cd 17. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b16dd 18. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:33.855377 [ 4644 ] {} ExternalDictionaries: Could not update cache dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)', next update is scheduled at 2025-10-23 23:51:39: Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.view_for_dict' in scope SELECT key_column, second_column, third_column FROM ordinary_db.view_for_dict WHERE key_column IN (867, 909). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d594c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996bc 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000000fe64c6e 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000000fe650cd 17. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b16dd 18. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:34.407656 [ 4097 ] {0faf6f16-8630-4165-a4cc-b6baad3ca07f} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) : Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.view_for_dict' in scope SELECT key_column, second_column, third_column FROM ordinary_db.view_for_dict WHERE key_column IN (888, 311). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d594c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996bc 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000000fe64c6e 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000000fe650cd 17. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b16dd 18. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45066) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:34.407658 [ 4098 ] {7a8ba0db-6aea-4f02-84b5-10fee8e8d15d} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45080) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:34.408024 [ 4060 ] {eb28566d-bd22-4b2a-a8fe-c769c62f65d6} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45062) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:34.407944 [ 4059 ] {824dac96-eb60-4c19-b821-f4d9822ac626} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) : Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.view_for_dict' in scope SELECT key_column, second_column, third_column FROM ordinary_db.view_for_dict WHERE key_column IN (867, 909). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d594c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996bc 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000000fe64c6e 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000000fe650cd 17. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b16dd 18. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45054) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:34.408148 [ 4100 ] {531faaca-19c5-40d7-8768-278fce4d4e1a} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45084) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:34.408256 [ 4105 ] {29c4999f-e85f-4927-86ff-118e3860d685} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45096) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:34.410499 [ 4097 ] {0faf6f16-8630-4165-a4cc-b6baad3ca07f} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) : Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.view_for_dict' in scope SELECT key_column, second_column, third_column FROM ordinary_db.view_for_dict WHERE key_column IN (888, 311). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d594c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996bc 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000000fe64c6e 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000000fe650cd 17. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b16dd 18. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:34.412120 [ 4098 ] {7a8ba0db-6aea-4f02-84b5-10fee8e8d15d} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:34.412170 [ 4060 ] {eb28566d-bd22-4b2a-a8fe-c769c62f65d6} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:34.413709 [ 4105 ] {29c4999f-e85f-4927-86ff-118e3860d685} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:34.414557 [ 4059 ] {824dac96-eb60-4c19-b821-f4d9822ac626} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) : Code: 60. DB::Exception: Unknown table expression identifier 'ordinary_db.view_for_dict' in scope SELECT key_column, second_column, third_column FROM ordinary_db.view_for_dict WHERE key_column IN (867, 909). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d594c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996bc 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000000fe64c6e 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::ClickHouseDictionarySource::loadIds(std::vector> const&) @ 0x000000000fe650cd 17. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b16dd 18. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:34.417412 [ 4100 ] {531faaca-19c5-40d7-8768-278fce4d4e1a} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:34.860581 [ 4105 ] {ba292a3d-dda5-414c-b667-cee7a64e91f6} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45208) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:34.861979 [ 4105 ] {ba292a3d-dda5-414c-b667-cee7a64e91f6} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:34.895464 [ 4099 ] {736a8b7a-b42d-49c3-af74-d2ee1d81a21d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=746, jobs=719). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45228) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:51:34.896979 [ 4099 ] {736a8b7a-b42d-49c3-af74-d2ee1d81a21d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=746, jobs=719). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:51:34.982361 [ 4102 ] {3f1410a0-c10b-4526-89e7-e46befa0acb8} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45196) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:34.982564 [ 4108 ] {95c51d5f-4e69-4de5-a600-c430c5c15ce9} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45242) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:34.982775 [ 2689 ] {440060a8-2449-4627-ae1a-bac8d4db1ad0} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45214) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:34.982898 [ 2687 ] {798518b4-006e-4df1-910b-aa5acfea3977} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45238) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:34.984789 [ 4102 ] {3f1410a0-c10b-4526-89e7-e46befa0acb8} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:34.985721 [ 4108 ] {95c51d5f-4e69-4de5-a600-c430c5c15ce9} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:34.986492 [ 2689 ] {440060a8-2449-4627-ae1a-bac8d4db1ad0} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:34.986768 [ 2687 ] {798518b4-006e-4df1-910b-aa5acfea3977} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:35.088008 [ 3576 ] {3a469000-2717-4bf3-a4a6-79de0fcfa281} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:60146) (comment: 00161_parallel_parsing_with_names.sh) (in query: DROP DATABASE IF EXISTS test_ruc8r24l ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:51:35.091170 [ 3576 ] {3a469000-2717-4bf3-a4a6-79de0fcfa281} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:35.360783 [ 2689 ] {1dea16a4-300e-49ef-bda3-c12192865d00} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45280) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:35.362590 [ 2689 ] {1dea16a4-300e-49ef-bda3-c12192865d00} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:35.416949 [ 4096 ] {410f3b0f-84c0-413f-8ae5-944c59c2fc39} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/33f/33fe57df-80c6-4d43-85df-8cc2405b55d8/202510_16_16_0/ in table system.query_log (33fe57df-80c6-4d43-85df-8cc2405b55d8) located on disk default of type local, from mark 0 with max_rows_to_read = 333): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:44942) (comment: 00180_no_seek_avoiding_when_reading_from_cache.sh) (in query: -- AsynchronousReaderIgnoredBytes = 0: no seek-avoiding happened -- CachedReadBufferReadFromSourceBytes = 0: sanity check to ensure we read only from cache SELECT ProfileEvents['AsynchronousReaderIgnoredBytes'], ProfileEvents['CachedReadBufferReadFromSourceBytes'] FROM system.query_log WHERE query_id = '02906_read_from_cache_8740' AND type = 'QueryFinish' AND event_date >= yesterday() AND current_database = currentDatabase() ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d62f83 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d65385 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d655fe 16. DB::ReadBuffer::next() @ 0x0000000007b3717b 17. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000001702f769 18. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000001702df6f 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f58c32 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bcd448 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bee90e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5b63 26. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5b63 27. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5b63 28. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5b63 29. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 30. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a967e6a 31. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 2025.10.23 23:51:35.420555 [ 4096 ] {410f3b0f-84c0-413f-8ae5-944c59c2fc39} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/33f/33fe57df-80c6-4d43-85df-8cc2405b55d8/202510_16_16_0/ in table system.query_log (33fe57df-80c6-4d43-85df-8cc2405b55d8) located on disk default of type local, from mark 0 with max_rows_to_read = 333): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d62f83 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d65385 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d655fe 16. DB::ReadBuffer::next() @ 0x0000000007b3717b 17. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000001702f769 18. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000001702df6f 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f58c32 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bcd448 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bee90e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5b63 26. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5b63 27. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5b63 28. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5b63 29. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 30. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a967e6a 31. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 2025.10.23 23:51:35.434550 [ 4106 ] {35a49858-f512-4eb6-b4c3-7569e9f93080} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45290) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:35.436172 [ 4106 ] {35a49858-f512-4eb6-b4c3-7569e9f93080} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:35.467071 [ 4099 ] {cbd6f2d6-8bbd-4a6e-b06d-7e94f642f763} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45306) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:35.468237 [ 4099 ] {cbd6f2d6-8bbd-4a6e-b06d-7e94f642f763} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:35.483699 [ 2689 ] {ffd79ad3-ef6d-4eaf-a149-51c5bc52774a} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45316) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:35.485605 [ 2689 ] {ffd79ad3-ef6d-4eaf-a149-51c5bc52774a} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:35.519498 [ 2687 ] {f8393798-cb1b-459f-9744-5eec355aec56} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45328) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:35.519720 [ 4108 ] {1879c1c3-0d3d-41b0-91cc-1131a6e809c4} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45332) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:35.521273 [ 4108 ] {1879c1c3-0d3d-41b0-91cc-1131a6e809c4} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:35.521531 [ 2687 ] {f8393798-cb1b-459f-9744-5eec355aec56} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:35.724835 [ 4105 ] {fc19fce7-22d3-41b1-a1e4-0e944f4bf852} executeQuery: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value2 :: 0, 'UInt32' :: 1) -> _CAST(value2, 'UInt32') UInt32 : 2': (while reading from part /var/lib/clickhouse/store/11b/11b526bb-bffd-4b55-bfe0-1bf28b690b08/all_0_0_0_1/ located on disk default of type local): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_PARSE_TEXT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45266) (comment: 01079_bad_alters_zookeeper_long.sh) (in query: SELECT distinct(value2) FROM table_for_bad_alters), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000776fec0 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000077d40ca 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000077ca444 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007635b7e 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000779893f 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007765447 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087152b7 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x00000000176c9952 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000182425a5 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:0: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000019bd58ae 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be6eef 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a967e6a 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 25. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 26. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 2025.10.23 23:51:35.726917 [ 4105 ] {fc19fce7-22d3-41b1-a1e4-0e944f4bf852} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value2 :: 0, 'UInt32' :: 1) -> _CAST(value2, 'UInt32') UInt32 : 2': (while reading from part /var/lib/clickhouse/store/11b/11b526bb-bffd-4b55-bfe0-1bf28b690b08/all_0_0_0_1/ located on disk default of type local): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000776fec0 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x00000000077d40ca 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000077ca444 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000007635b7e 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000779893f 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007765447 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087152b7 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x00000000176c9952 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:119: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000182425a5 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:0: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x0000000019bd58ae 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be6eef 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a967e6a 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 25. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 26. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 2025.10.23 23:51:35.893234 [ 4105 ] {843fa2dd-a2a5-416a-bf07-54a13a870e82} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45346) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:35.895532 [ 4105 ] {843fa2dd-a2a5-416a-bf07-54a13a870e82} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:35.978610 [ 2687 ] {53ebd367-8ac0-4fc7-bfa2-6f74ac08a699} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45380) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:35.979981 [ 2687 ] {53ebd367-8ac0-4fc7-bfa2-6f74ac08a699} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:36.021958 [ 4108 ] {9f67a3a3-49b2-4618-95b6-54edc58e52bf} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45386) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:36.023578 [ 4108 ] {9f67a3a3-49b2-4618-95b6-54edc58e52bf} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:36.029506 [ 3875 ] {ecf0c67b-c261-4036-a93d-22dde436e7fc} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45400) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:36.030549 [ 4106 ] {fdb4d381-faa8-4af6-a8cc-0914239d60b5} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45360) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:36.031664 [ 3875 ] {ecf0c67b-c261-4036-a93d-22dde436e7fc} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:36.032751 [ 4106 ] {fdb4d381-faa8-4af6-a8cc-0914239d60b5} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:36.035048 [ 3565 ] {34376920-d3e3-4684-a9ee-147e5617d3e0} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45396) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:36.036208 [ 3565 ] {34376920-d3e3-4684-a9ee-147e5617d3e0} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:36.210111 [ 4099 ] {a9ff422a-daa0-42e5-818d-7e2f12c137e1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45372) (comment: 02941_variant_type_alters.sh) (in query: select x, y, y.UInt64, y.String, v, v.String, v.UInt64, v.Date from test order by x), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bfc297 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000019bfd21f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001704d7cb 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f581e4 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019bf9bd6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bf97d5 16. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x0000000019abec34 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aba072 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c63e3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 2025.10.23 23:51:36.213338 [ 4099 ] {a9ff422a-daa0-42e5-818d-7e2f12c137e1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bfc297 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000019bfd21f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001704d7cb 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f581e4 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019bf9bd6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bf97d5 16. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x0000000019abec34 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aba072 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c63e3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 2025.10.23 23:51:36.445482 [ 4099 ] {464107ef-1e77-4308-b1aa-581fb1bfffea} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45436) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:36.447782 [ 4099 ] {464107ef-1e77-4308-b1aa-581fb1bfffea} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:36.472448 [ 2687 ] {df9c544a-bcef-4ab6-8d71-e70f3f91df6e} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45448) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:36.473982 [ 2687 ] {df9c544a-bcef-4ab6-8d71-e70f3f91df6e} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:36.514378 [ 4108 ] {ca089240-05e3-40e2-8286-3531fe7cd2df} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45454) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:36.516148 [ 4108 ] {ca089240-05e3-40e2-8286-3531fe7cd2df} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:36.564394 [ 4105 ] {bfc7864e-d6ac-4b85-9bdd-907c233fb37e} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45478) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:36.565413 [ 4105 ] {bfc7864e-d6ac-4b85-9bdd-907c233fb37e} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:36.579862 [ 3565 ] {f4d4bd5b-1e96-4fbe-a0fe-b80b57d72c89} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45468) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:36.581549 [ 3565 ] {f4d4bd5b-1e96-4fbe-a0fe-b80b57d72c89} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:36.592226 [ 3155 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:36.693146 [ 4099 ] {077442c2-a0ac-49bf-ade2-1979fa3d023b} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45484) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:36.694638 [ 4099 ] {077442c2-a0ac-49bf-ade2-1979fa3d023b} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:36.966559 [ 4099 ] {115831da-f96b-4720-9aa1-b821c2d13654} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45514) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:36.967670 [ 4099 ] {115831da-f96b-4720-9aa1-b821c2d13654} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:37.005256 [ 4105 ] {44e82741-6334-47ef-9cb3-ad3f8fd4a8c5} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45504) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:37.006502 [ 4105 ] {44e82741-6334-47ef-9cb3-ad3f8fd4a8c5} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:37.097536 [ 4099 ] {84da26c7-4671-4e4b-8254-01048f1a51b9} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45538) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:37.099742 [ 4099 ] {84da26c7-4671-4e4b-8254-01048f1a51b9} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:37.127008 [ 4108 ] {a41707ad-cfef-4799-8d49-19d41d468082} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45534) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:37.130387 [ 4108 ] {a41707ad-cfef-4799-8d49-19d41d468082} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:37.142120 [ 2689 ] {fee97b4a-80f4-461e-a0c4-bfc704268402} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45528) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:37.144047 [ 2689 ] {fee97b4a-80f4-461e-a0c4-bfc704268402} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:37.204003 [ 3116 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:37.343528 [ 2687 ] {3eee621c-7fc5-4ab8-a50e-0ec9820260a0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45578) (comment: 02941_variant_type_alters.sh) (in query: select x, y, y.UInt64, y.String, v, v.String, v.UInt64, v.Date from test order by x), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bfc297 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000019bfd21f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001704d7cb 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f581e4 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019bf9bd6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bf97d5 16. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x0000000019abec34 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aba072 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c63e3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 2025.10.23 23:51:37.348054 [ 2687 ] {3eee621c-7fc5-4ab8-a50e-0ec9820260a0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bfc297 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000019bfd21f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001704d7cb 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f581e4 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019bf9bd6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bf97d5 16. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x0000000019abec34 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aba072 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c63e3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 2025.10.23 23:51:37.399296 [ 4099 ] {62d16183-7698-4c63-96bd-c6a9e7ddc053} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45564) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:37.401331 [ 4099 ] {62d16183-7698-4c63-96bd-c6a9e7ddc053} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:37.469573 [ 4108 ] {0d86ed77-a32b-4c8d-a289-57853ee9d714} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45616) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:37.470435 [ 4108 ] {0d86ed77-a32b-4c8d-a289-57853ee9d714} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:37.628030 [ 2689 ] {9f9c0953-f6fb-4823-8660-0b1cbfe26d67} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45602) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:37.628105 [ 4106 ] {73911642-130e-47a7-8e95-1bff2ac5d626} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45626) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:37.629988 [ 4106 ] {73911642-130e-47a7-8e95-1bff2ac5d626} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:37.630053 [ 2689 ] {9f9c0953-f6fb-4823-8660-0b1cbfe26d67} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:37.637276 [ 4099 ] {d81dfb5d-102b-4cb5-8d83-320c86fa5b58} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45630) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:37.638771 [ 4099 ] {d81dfb5d-102b-4cb5-8d83-320c86fa5b58} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:37.734721 [ 2687 ] {1d753d58-43e1-4b46-9cd5-c46dd457c9b9} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45632) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:37.736888 [ 2687 ] {1d753d58-43e1-4b46-9cd5-c46dd457c9b9} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.024831 [ 2687 ] {3f701768-ebd8-4e82-83ae-f30dd38b98ed} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45660) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.027123 [ 2687 ] {3f701768-ebd8-4e82-83ae-f30dd38b98ed} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.055058 [ 4019 ] {1473bafe-70a4-4d99-92a2-b2cbd59b0724} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45664) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.056930 [ 4019 ] {1473bafe-70a4-4d99-92a2-b2cbd59b0724} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.123819 [ 3875 ] {acfb4857-c270-412d-a5a4-ab1865d3eb5e} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45670) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.125716 [ 3875 ] {acfb4857-c270-412d-a5a4-ab1865d3eb5e} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.212660 [ 3683 ] {a3adfcd8-fe18-4eac-85a1-ef9f25f31516} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45680) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.215428 [ 3683 ] {a3adfcd8-fe18-4eac-85a1-ef9f25f31516} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.243231 [ 3565 ] {3fe43956-da96-4693-b3c0-71433ce95569} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45692) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.245370 [ 3565 ] {3fe43956-da96-4693-b3c0-71433ce95569} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.288964 [ 4108 ] {f6cabe4e-aab5-43b4-a96e-3211a7356754} executeQuery: Code: 36. DB::Exception: Wrong index name. Cannot find index `idx2` to drop. (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45634) (comment: 01079_bad_alters_zookeeper_long.sh) (in query: ALTER TABLE table_for_bad_alters DROP INDEX idx2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x0000000009575ec6 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000190e3f94 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000190e7ed9 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199e8e34 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c296fb 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.291007 [ 4108 ] {f6cabe4e-aab5-43b4-a96e-3211a7356754} TCPHandler: Code: 36. DB::Exception: Wrong index name. Cannot find index `idx2` to drop. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x0000000009575ec6 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000190e3f94 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x00000000190e7ed9 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199e8e34 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c296fb 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.292260 [ 2687 ] {a32893b8-9073-49c2-a25a-2502d3246ca5} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45694) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.295872 [ 2687 ] {a32893b8-9073-49c2-a25a-2502d3246ca5} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.539877 [ 2687 ] {95541278-244f-4226-aa7a-f2624ee818fb} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45706) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.540959 [ 2687 ] {95541278-244f-4226-aa7a-f2624ee818fb} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.597679 [ 3875 ] {f9de45b3-ed8f-400b-aeac-8f79ff7dca5c} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45736) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.599335 [ 3875 ] {f9de45b3-ed8f-400b-aeac-8f79ff7dca5c} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.664118 [ 2687 ] {26f7b1fb-ee47-4497-8234-14288e9900ff} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45766) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.665524 [ 2687 ] {26f7b1fb-ee47-4497-8234-14288e9900ff} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.757634 [ 3875 ] {6e1f4131-67ec-4645-b15d-3d99e4d9beab} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45772) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.758554 [ 3875 ] {6e1f4131-67ec-4645-b15d-3d99e4d9beab} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.825652 [ 4019 ] {23a4a30f-90b6-4d65-a826-d985d521d90f} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45792) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.827547 [ 4019 ] {23a4a30f-90b6-4d65-a826-d985d521d90f} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.827727 [ 2687 ] {708bb338-ae98-475c-b334-b7073b925369} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45782) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:38.829060 [ 2687 ] {708bb338-ae98-475c-b334-b7073b925369} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:39.097845 [ 2687 ] {ae7f88d2-3f6c-4293-8962-f90f6a6211c7} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57590) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:39.100382 [ 2687 ] {ae7f88d2-3f6c-4293-8962-f90f6a6211c7} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:39.164765 [ 3683 ] {960ac3b4-b106-4180-836c-c9b8b0f598e5} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57606) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:39.166597 [ 3683 ] {960ac3b4-b106-4180-836c-c9b8b0f598e5} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:39.203257 [ 3873 ] {9828d551-9853-447a-88ac-6daa4065e7bc} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57612) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:39.205714 [ 3873 ] {9828d551-9853-447a-88ac-6daa4065e7bc} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:39.284139 [ 3683 ] {01353a00-3f96-4eeb-9d8d-79ce22b27187} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57642) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:39.285080 [ 3683 ] {01353a00-3f96-4eeb-9d8d-79ce22b27187} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:39.317321 [ 4059 ] {83668a1c-93a6-467c-9435-3ee6018f014f} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57658) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:39.319089 [ 4059 ] {83668a1c-93a6-467c-9435-3ee6018f014f} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 2025-10-23 23:51:39. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:39.545902 [ 4108 ] {787052f7-13ce-4b19-ad72-c90e07e2f3be} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=746, jobs=722). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45722) (comment: 02475_join_bug_42832.sql) (in query: SELECT sum(val), count(val) FROM tab1 FULL OUTER JOIN tab2 ON b1 - 2 = a2 OR a1 = b2 SETTINGS join_use_nulls = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:51:39.548089 [ 4108 ] {787052f7-13ce-4b19-ad72-c90e07e2f3be} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=746, jobs=722). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:51:39.645763 [ 4100 ] {52096fea-2bd6-4b43-b633-57ba32dd8bd9} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:35724) (comment: 02475_join_bug_42832.sql) (in query: DROP DATABASE IF EXISTS test_j6kxbx2o ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:51:39.647514 [ 4100 ] {52096fea-2bd6-4b43-b633-57ba32dd8bd9} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:39.952385 [ 2687 ] {aaa62fa2-3040-4128-a1b4-ad673ce36fe8} executeQuery: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness RightAny. (NOT_IMPLEMENTED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57628) (comment: 00063_loyalty_joins.sql) (in query: SELECT loyalty, count() FROM test.hits ANY LEFT JOIN ( SELECT UserID, sum(SearchEngineID = 2) AS yandex, sum(SearchEngineID = 3) AS google, toInt8(if(yandex > google, yandex / (yandex + google), -google / (yandex + google)) * 10) AS loyalty FROM test.hits WHERE (SearchEngineID = 2) OR (SearchEngineID = 3) GROUP BY UserID HAVING (yandex + google) > 10 ) USING UserID GROUP BY loyalty ORDER BY loyalty ASC;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x000000001a6ce900 4. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x000000001a6c35dc 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:476: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x000000001a6c39cc 6. ./src/Processors/Merges/IMergingTransform.h:166: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x000000001a6cd9b2 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x0000000016df2cad 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a904c57 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9210b9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dc3569 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017dc3210 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.23 23:51:39.960262 [ 2687 ] {aaa62fa2-3040-4128-a1b4-ad673ce36fe8} TCPHandler: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness RightAny. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x000000001a6ce900 4. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x000000001a6c35dc 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:476: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x000000001a6c39cc 6. ./src/Processors/Merges/IMergingTransform.h:166: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x000000001a6cd9b2 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x0000000016df2cad 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a904c57 9. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9210b9 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dc3569 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017dc3210 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.23 23:51:41.004662 [ 5099 ] {} ExternalDictionaries: Could not update cache dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)', next update is scheduled at 2025-10-23 23:51:45: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/396/396b75f8-4a0b-42ae-b64e-8c0c0db9a5b1/all_1_1_0/ in table ordinary_db.table_for_dict_real (396b75f8-4a0b-42ae-b64e-8c0c0db9a5b1) located on disk default of type local, from mark 0 with max_rows_to_read = 2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d62f83 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d65385 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d655fe 16. DB::ReadBuffer::next() @ 0x0000000007b3717b 17. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:85: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000001702b2e9 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bcd448 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bee90e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5b63 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a98c8ea 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 28. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 29. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:41.007828 [ 3873 ] {858a6292-2bf1-4a8a-9540-dfca868c7d78} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 1970-01-01 01:00:00. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57696) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:41.008980 [ 3873 ] {858a6292-2bf1-4a8a-9540-dfca868c7d78} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Query contains keys that are not present in cache or expired. Could not update cache dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) now, because nearest update is scheduled at 1970-01-01 01:00:00. Try again later. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b37e4 5. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:41.010039 [ 3875 ] {fd55dd98-2606-4fba-ac9a-98c2caeba008} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) : Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/396/396b75f8-4a0b-42ae-b64e-8c0c0db9a5b1/all_1_1_0/ in table ordinary_db.table_for_dict_real (396b75f8-4a0b-42ae-b64e-8c0c0db9a5b1) located on disk default of type local, from mark 0 with max_rows_to_read = 2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d62f83 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d65385 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d655fe 16. DB::ReadBuffer::next() @ 0x0000000007b3717b 17. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:85: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000001702b2e9 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bcd448 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bee90e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5b63 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a98c8ea 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 28. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 29. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 (version 24.8.14.10544.altinitytest (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57674) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:41.014103 [ 3875 ] {fd55dd98-2606-4fba-ac9a-98c2caeba008} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)': Code: 510. DB::Exception: Update failed for dictionary ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2) : Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/396/396b75f8-4a0b-42ae-b64e-8c0c0db9a5b1/all_1_1_0/ in table ordinary_db.table_for_dict_real (396b75f8-4a0b-42ae-b64e-8c0c0db9a5b1) located on disk default of type local, from mark 0 with max_rows_to_read = 2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d62f83 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d65385 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d655fe 16. DB::ReadBuffer::next() @ 0x0000000007b3717b 17. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:85: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000001702b2e9 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bcd448 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bee90e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5b63 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a98c8ea 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 28. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 29. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 (version 24.8.14.10544.altinitytest (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10544.altinitytest (altinity build)): while executing 'FUNCTION dictGetString('ordinary_db.dict1'_String :: 1, 'third_column'_String :: 2, toUInt64(modulo(rand(), 1000_UInt16)) :: 4) -> dictGetString('ordinary_db.dict1'_String, 'third_column'_String, toUInt64(modulo(rand(), 1000_UInt16))) String : 5'. (CACHE_DICTIONARY_UPDATE_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:0: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x00000000101c637a 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101aca54 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x00000000101abaf7 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x0000000007b99e0f 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007b968b8 9. DB::FunctionDictGetImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007bbeb67 10. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 17. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 18. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 22. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:51:41.497655 [ 4060 ] {188fa60b-cee3-40ed-84f6-babe931eb9ec} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2): While executing RecursiveCTESource. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57712) (comment: 03037_recursive_cte_postgres_3.sql) (in query: -- just count 'em WITH RECURSIVE t AS ( SELECT 1 AS id, []::Array(UInt64) AS path UNION ALL SELECT tree.id, arrayConcat(t.path, [tree.id]) FROM tree JOIN t ON (tree.parent_id = t.id) ) SELECT t1.id, count(t2.path) FROM t AS t1 JOIN t AS t2 ON (t1.path[1] = t2.path[1] AND length(t1.path) = 1 AND length(t2.path) > 1) GROUP BY t1.id ORDER BY t1.id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:51:41.504236 [ 4060 ] {188fa60b-cee3-40ed-84f6-babe931eb9ec} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2): While executing RecursiveCTESource. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:51:44.984746 [ 3322 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {34e0b00e-fe5a-47d8-af0c-3ae1d30a34d1::202510_1_56_11}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:45.791498 [ 4097 ] {8fdc02c3-9f23-4a40-9f13-666e4e91b8fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 0, should be 1: In scope SELECT variantType() FROM test. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57986) (comment: 02981_variant_type_function.sql) (in query: SELECT variantType() FROM test;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871a62c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008717669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:51:45.792149 [ 4097 ] {8fdc02c3-9f23-4a40-9f13-666e4e91b8fb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 0, should be 1: In scope SELECT variantType() FROM test. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871a62c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008717669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:51:45.801709 [ 4097 ] {02ee5c65-de61-4e5f-9dd2-56c139f707e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 2, should be 1: In scope SELECT variantType(v, v) FROM test. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57986) (comment: 02981_variant_type_function.sql) (in query: SELECT variantType(v, v) FROM test;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871a62c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008717669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:51:45.802760 [ 4097 ] {02ee5c65-de61-4e5f-9dd2-56c139f707e2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 2, should be 1: In scope SELECT variantType(v, v) FROM test. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871a62c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008717669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:51:46.345350 [ 4097 ] {e4ac5f91-1ad2-4f7c-9557-4b1d737f507a} executeQuery: Code: 43. DB::Exception: First argument for function variantType must be Variant, got Nullable(String) instead: In scope SELECT variantType(v.String) FROM test. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57986) (comment: 02981_variant_type_function.sql) (in query: SELECT variantType(v.String) FROM test;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::(anonymous namespace)::FunctionVariantType::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e54d963 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 30. __tsan_thread_start_func @ 0x000000000758df2f 31. ? @ 0x00007f7c69445ac3 2025.10.23 23:51:46.346479 [ 4097 ] {e4ac5f91-1ad2-4f7c-9557-4b1d737f507a} TCPHandler: Code: 43. DB::Exception: First argument for function variantType must be Variant, got Nullable(String) instead: In scope SELECT variantType(v.String) FROM test. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::(anonymous namespace)::FunctionVariantType::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e54d963 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 30. __tsan_thread_start_func @ 0x000000000758df2f 31. ? @ 0x00007f7c69445ac3 2025.10.23 23:51:46.698713 [ 4019 ] {3f7e50db-972d-4635-9f2e-2addcdb8c4f9} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:35790) (comment: 02981_variant_type_function.sql) (in query: DROP DATABASE IF EXISTS test_ji8z3ksb ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:51:46.700672 [ 4019 ] {3f7e50db-972d-4635-9f2e-2addcdb8c4f9} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:46.713479 [ 4098 ] {901e33e0-0d77-4118-90ea-b3b4110054b1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:35806) (comment: 02981_variant_type_function.sql) (in query: DROP DATABASE IF EXISTS test_ji8z3ksb ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:51:46.715136 [ 4098 ] {901e33e0-0d77-4118-90ea-b3b4110054b1} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:47.283891 [ 4059 ] {38444e5d-37d6-4b8c-9622-6dd31a9cd41d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57978) (comment: 00177_memory_bound_merging.sh) (in query: SELECT COUNT() > 0 FROM system.text_log WHERE query_id IN (SELECT query_id FROM system.query_log WHERE query_id != 'query_id_memory_bound_merging_172915287' AND initial_query_id = 'query_id_memory_bound_merging_172915287' AND event_date >= yesterday()) AND event_date >= yesterday() AND message ILIKE '%Reading%ranges in order%'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c143b7 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c63e3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 28. __tsan_thread_start_func @ 0x000000000758df2f 29. ? @ 0x00007f7c69445ac3 30. ? @ 0x00007f7c694d7850 2025.10.23 23:51:47.286219 [ 4059 ] {38444e5d-37d6-4b8c-9622-6dd31a9cd41d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c143b7 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c63e3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 28. __tsan_thread_start_func @ 0x000000000758df2f 29. ? @ 0x00007f7c69445ac3 30. ? @ 0x00007f7c694d7850 2025.10.23 23:51:48.628981 [ 2837 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:51.736505 [ 4105 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000001682a339 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175b6066 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175b675b 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a206a77 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1f6dd1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1eb38f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:51:52.093848 [ 4100 ] {f48ed0b3-3511-43f8-b750-410af533a074} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36146) (comment: 00015_totals_and_no_aggregate_functions.sql) (in query: SELECT AdvEngineID FROM test.hits GROUP BY AdvEngineID WITH TOTALS ORDER BY AdvEngineID ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:51:52.095895 [ 4100 ] {f48ed0b3-3511-43f8-b750-410af533a074} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:51:52.668853 [ 4019 ] {bc92f755-b910-43b9-b5ec-9b9adf0f19d8} executeQuery: Code: 60. DB::Exception: Table test_2brohqi9.t_json_16 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36160) (comment: 01825_type_json_16.sh) (in query: INSERT INTO t_json_16 FORMAT JSONAsObject), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017141363 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000017697dc1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001769f180 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d45ccf 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f0da 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:51:52.670670 [ 4019 ] {bc92f755-b910-43b9-b5ec-9b9adf0f19d8} TCPHandler: Code: 60. DB::Exception: Table test_2brohqi9.t_json_16 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017141363 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000017697dc1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001769f180 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d45ccf 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f0da 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:51:53.219147 [ 4106 ] {b71f66f5-3b4e-4e08-b1b8-3aff5e49e83a} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:36084). (NETWORK_ERROR) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36084) (comment: 01412_cache_dictionary_race.sh) (in query: SELECT dictGetString('ordinary_db.dict1', 'third_column', toUInt64(rand() % 1000)) from numbers(2)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe5aed 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe7532 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a06e78e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000001a1fc95d 6. ./build_docker/./src/Server/TCPHandler.cpp:1143: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f95d6 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 2025.10.23 23:51:53.355909 [ 4106 ] {b71f66f5-3b4e-4e08-b1b8-3aff5e49e83a} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:36084). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe5aed 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe76f0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a06e78e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000001a20b607 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000001a1fabfc 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec459 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:53.356241 [ 4106 ] {b71f66f5-3b4e-4e08-b1b8-3aff5e49e83a} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::1]:9000 -> [::1]:36084). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe5aed 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe7532 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a06e78e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000001a1fc95d 6. ./build_docker/./src/Server/TCPHandler.cpp:1143: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f95d6 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 2025.10.23 23:51:53.356718 [ 4106 ] {b71f66f5-3b4e-4e08-b1b8-3aff5e49e83a} TCPHandler: Client has gone away. 2025.10.23 23:51:53.706596 [ 2687 ] {4e029d02-b0ae-4aaf-be92-49263502b887} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_16' in scope SELECT DISTINCT toTypeName(obj) FROM t_json_16. (UNKNOWN_TABLE) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36182) (comment: 01825_type_json_16.sh) (in query: SELECT DISTINCT toTypeName(obj) FROM t_json_16;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d594c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996bc 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 2025.10.23 23:51:53.708233 [ 2687 ] {4e029d02-b0ae-4aaf-be92-49263502b887} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_16' in scope SELECT DISTINCT toTypeName(obj) FROM t_json_16. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d594c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996bc 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 2025.10.23 23:51:53.870508 [ 4108 ] {1d2c6b65-632d-4225-a747-e2624f7b89af} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36188) (comment: 01412_cache_dictionary_race.sh) (in query: DROP DATABASE IF EXISTS ordinary_db), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c771c0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c792ca 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:51:53.872167 [ 4108 ] {1d2c6b65-632d-4225-a747-e2624f7b89af} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c771c0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c792ca 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:51:53.972803 [ 3412 ] {} ExternalDictionaries: Could not update cache dictionary 'ordinary_db.dict1 (097b61f4-68f2-4a0a-9614-959c183365b2)', next update is scheduled at 2025-10-23 23:51:57: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c143b7 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c63e3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 23. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a30a201 25. ./build_docker/./src/Dictionaries/DictionaryPipelineExecutor.cpp:0: DB::DictionaryPipelineExecutor::pull(DB::Block&) @ 0x000000000ff54611 26. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x00000000101b1861 27. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x00000000101c29a7 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x00000000101c652c 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000101c9062 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:54.359283 [ 2687 ] {5d70e013-e7cf-4b6b-8747-8ba0fcbb98ea} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_16' in scope SELECT obj FROM t_json_16 ORDER BY obj.id ASC. (UNKNOWN_TABLE) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36208) (comment: 01825_type_json_16.sh) (in query: SELECT obj FROM t_json_16 ORDER BY obj.id FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d594c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996bc 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 2025.10.23 23:51:54.361503 [ 2687 ] {5d70e013-e7cf-4b6b-8747-8ba0fcbb98ea} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_16' in scope SELECT obj FROM t_json_16 ORDER BY obj.id ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d594c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996bc 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 2025.10.23 23:51:54.808837 [ 3875 ] {e4070e8c-fb1a-4943-ab99-8c11808bd5b3} executeQuery: Code: 44. DB::Exception: Illegal columns of arguments of function range, the function only implemented for unsigned/signed integers up to 64 bit: In scope SELECT range(toUInt256(1), 1). (ILLEGAL_COLUMN) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36232) (comment: 01780_range_msan.sql) (in query: SELECT range(toUInt256(1), 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f9678ca 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.23 23:51:54.810008 [ 3875 ] {e4070e8c-fb1a-4943-ab99-8c11808bd5b3} TCPHandler: Code: 44. DB::Exception: Illegal columns of arguments of function range, the function only implemented for unsigned/signed integers up to 64 bit: In scope SELECT range(toUInt256(1), 1). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f9678ca 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.23 23:51:55.012577 [ 2687 ] {cd9e32e2-0382-4bfc-bf1f-387ff996e2bb} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_16' in scope SELECT obj.key_0.key_1.key_2.key_3.key_4, obj.key_0.key_1.key_2.key_3.key_6, obj.key_0.key_1.key_2.key_3.key_7, obj.key_0.key_1.key_2.key_5.key_6, obj.key_0.key_1.key_2.key_5.key_7 FROM t_json_16 ORDER BY obj.id ASC. (UNKNOWN_TABLE) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36246) (comment: 01825_type_json_16.sh) (in query: SELECT obj.key_0.key_1.key_2.key_3.key_4, obj.key_0.key_1.key_2.key_3.key_6, obj.key_0.key_1.key_2.key_3.key_7, obj.key_0.key_1.key_2.key_5.key_6, obj.key_0.key_1.key_2.key_5.key_7 FROM t_json_16 ORDER BY obj.id), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d594c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996bc 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 2025.10.23 23:51:55.014392 [ 2687 ] {cd9e32e2-0382-4bfc-bf1f-387ff996e2bb} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_16' in scope SELECT obj.key_0.key_1.key_2.key_3.key_4, obj.key_0.key_1.key_2.key_3.key_6, obj.key_0.key_1.key_2.key_3.key_7, obj.key_0.key_1.key_2.key_5.key_6, obj.key_0.key_1.key_2.key_5.key_7 FROM t_json_16 ORDER BY obj.id ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d594c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996bc 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 2025.10.23 23:51:55.953402 [ 4108 ] {762e41b2-5f5f-4dc2-992d-93dde32e638f} executeQuery: Code: 60. DB::Exception: Table test_2brohqi9.t_json_16 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36284) (comment: 01825_type_json_16.sh) (in query: DROP TABLE t_json_16;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017141363 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000017697dc1 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:971: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001769f384 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c7515b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c74615 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c739c9 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.23 23:51:55.957245 [ 4108 ] {762e41b2-5f5f-4dc2-992d-93dde32e638f} TCPHandler: Code: 60. DB::Exception: Table test_2brohqi9.t_json_16 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017141363 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000017697dc1 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:971: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001769f384 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c7515b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c74615 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c739c9 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.23 23:51:57.204108 [ 4108 ] {dbe0e061-aaff-4714-96b1-0dcd5e17b4ae} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36322) (comment: 01277_buffer_column_order.sql) (in query: drop table buffer_01277;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1e9f1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c766aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c74615 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c739c9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:51:57.205830 [ 4108 ] {dbe0e061-aaff-4714-96b1-0dcd5e17b4ae} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1e9f1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c766aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c74615 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c739c9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:51:57.542644 [ 4099 ] {9009dd87-f20d-4259-bd3d-1105460e4c61} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:40006) (comment: 01277_buffer_column_order.sql) (in query: DROP DATABASE IF EXISTS test_nfc312vg ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1e9f1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c766aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c792ca 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.23 23:51:57.559546 [ 4099 ] {9009dd87-f20d-4259-bd3d-1105460e4c61} DynamicQueryHandler: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1e9f1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c766aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c792ca 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:51:58.005339 [ 2687 ] {25334575-7eb2-4f43-b3a8-82eb233db0ce} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36342) (comment: 00024_random_counters.sql) (in query: SELECT uniq(UserID), sum(Sign) FROM test.visits WHERE CounterID = 22202319;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:51:58.007394 [ 2687 ] {25334575-7eb2-4f43-b3a8-82eb233db0ce} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:51:59.546726 [ 4108 ] {7b78b423-a1a2-4c76-a1b2-4660e8fa29c0} executeQuery: Code: 183. DB::Exception: Unexpected expression '*' in filter in WHERE. In query SELECT * WHERE *. (UNEXPECTED_EXPRESSION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36358) (comment: 03101_analyzer_identifiers_3.sql) (in query: SELECT * WHERE *;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl::type, std::type_identity>&>::type, std::type_identity::type>, String&&, std::basic_string_view>&, String&&) @ 0x000000001751518c 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000017511bab 5. ./contrib/llvm-project/libcxx/include/vector:1501: DB::validateFilters(std::shared_ptr const&) @ 0x0000000017511819 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749b1eb 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 13. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 23. __tsan_thread_start_func @ 0x000000000758df2f 24. ? @ 0x00007f7c69445ac3 25. ? @ 0x00007f7c694d7850 2025.10.23 23:51:59.547523 [ 4108 ] {7b78b423-a1a2-4c76-a1b2-4660e8fa29c0} TCPHandler: Code: 183. DB::Exception: Unexpected expression '*' in filter in WHERE. In query SELECT * WHERE *. (UNEXPECTED_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl::type, std::type_identity>&>::type, std::type_identity::type>, String&&, std::basic_string_view>&, String&&) @ 0x000000001751518c 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000017511bab 5. ./contrib/llvm-project/libcxx/include/vector:1501: DB::validateFilters(std::shared_ptr const&) @ 0x0000000017511819 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749b1eb 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 13. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 23. __tsan_thread_start_func @ 0x000000000758df2f 24. ? @ 0x00007f7c69445ac3 25. ? @ 0x00007f7c694d7850 2025.10.23 23:52:01.863919 [ 2687 ] {2649051f-21d7-4581-a714-caeaffee409e} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45406) (comment: 00940_order_by_read_in_order_query_plan.sql) (in query: SET optimize_read_in_order = 1, query_plan_read_in_order = 1, enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:52:01.864969 [ 2687 ] {2649051f-21d7-4581-a714-caeaffee409e} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:52:10.679908 [ 2687 ] {f6937d3d-ed77-4f5a-952d-a16f1afcf7d2} executeQuery: Code: 524. DB::Exception: ALTER of key column enum_key from type Enum8('y' = 1, 'x' = 2, 'z' = 3) to type Enum16('y' = 1, 'x' = 2, 'z' = 3) is not safe because it can change the representation of primary key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43586) (comment: 01611_string_to_low_cardinality_key_alter.sql) (in query: ALTER TABLE table_with_lc_key MODIFY COLUMN enum_key Enum16('x' = 2, 'y' = 1, 'z' = 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000771b8ac 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199ee2d6 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c296fb 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:52:10.681131 [ 2687 ] {f6937d3d-ed77-4f5a-952d-a16f1afcf7d2} TCPHandler: Code: 524. DB::Exception: ALTER of key column enum_key from type Enum8('y' = 1, 'x' = 2, 'z' = 3) to type Enum16('y' = 1, 'x' = 2, 'z' = 3) is not safe because it can change the representation of primary key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000771b8ac 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199ee2d6 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c296fb 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:52:11.424215 [ 2687 ] {9d948d1e-f4c4-4f2b-8aed-e718de7aee1c} executeQuery: Code: 524. DB::Exception: ALTER of key column int_key from type Int8 to type Enum8('y' = 1, 'x' = 2) is not safe because it can change the representation of primary key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43586) (comment: 01611_string_to_low_cardinality_key_alter.sql) (in query: ALTER TABLE table_with_string_key MODIFY COLUMN int_key Enum8('y' = 1, 'x' = 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000771b8ac 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199ee2d6 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c296fb 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:52:11.425037 [ 2687 ] {9d948d1e-f4c4-4f2b-8aed-e718de7aee1c} TCPHandler: Code: 524. DB::Exception: ALTER of key column int_key from type Int8 to type Enum8('y' = 1, 'x' = 2) is not safe because it can change the representation of primary key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000771b8ac 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199ee2d6 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c296fb 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:52:12.145989 [ 4108 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000001682a339 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175b6066 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175b675b 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a206a77 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1f6dd1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1eb38f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:52:12.404856 [ 2687 ] {74e26441-8055-4328-b0ca-869e139893ac} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43622) (comment: 01015_database_bad_tables.sh) (in query: SELECT * FROM lazy_test_r3ihguop.test;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:52:12.406265 [ 2687 ] {74e26441-8055-4328-b0ca-869e139893ac} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:52:13.836233 [ 4108 ] {5bea5502-5077-4e1c-a402-7900d792df7f} executeQuery: Code: 42. DB::Exception: Array data type family must have exactly one argument - type of elements: In scope SELECT CAST(0, 'Array'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43642) (comment: 00540_bad_data_types.sh) (in query: SELECT CAST(0 AS Array)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/DataTypes/DataTypeArray.cpp:102: DB::create(std::shared_ptr const&) @ 0x0000000016e40f5b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000016e3f8c4 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000016e5a0e7 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x0000000016e59c3b 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:31: DB::DataTypeFactory::get(String const&) const @ 0x0000000016e576a1 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761d46a 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 2025.10.23 23:52:13.837764 [ 4108 ] {5bea5502-5077-4e1c-a402-7900d792df7f} TCPHandler: Code: 42. DB::Exception: Array data type family must have exactly one argument - type of elements: In scope SELECT CAST(0, 'Array'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/DataTypes/DataTypeArray.cpp:102: DB::create(std::shared_ptr const&) @ 0x0000000016e40f5b 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000016e3f8c4 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000016e5a0e7 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x0000000016e59c3b 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:31: DB::DataTypeFactory::get(String const&) const @ 0x0000000016e576a1 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761d46a 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 2025.10.23 23:52:14.992159 [ 4108 ] {45482928-b3cf-4dca-b247-5e450e1eea55} executeQuery: Code: 42. DB::Exception: Data type AggregateFunction requires parameters: version(optionally), name of aggregate function and list of data types for arguments: In scope SELECT CAST(0, 'AggregateFunction'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43650) (comment: 00540_bad_data_types.sh) (in query: SELECT CAST(0 AS AggregateFunction)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/DataTypes/DataTypeAggregateFunction.cpp:209: DB::create(std::shared_ptr const&) @ 0x0000000016e3e4c5 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000016e3f8c4 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000016e5a0e7 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x0000000016e59c3b 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:31: DB::DataTypeFactory::get(String const&) const @ 0x0000000016e576a1 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761d46a 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 2025.10.23 23:52:14.994070 [ 4108 ] {45482928-b3cf-4dca-b247-5e450e1eea55} TCPHandler: Code: 42. DB::Exception: Data type AggregateFunction requires parameters: version(optionally), name of aggregate function and list of data types for arguments: In scope SELECT CAST(0, 'AggregateFunction'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/DataTypes/DataTypeAggregateFunction.cpp:209: DB::create(std::shared_ptr const&) @ 0x0000000016e3e4c5 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000016e3f8c4 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000016e5a0e7 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x0000000016e59c3b 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:31: DB::DataTypeFactory::get(String const&) const @ 0x0000000016e576a1 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761d46a 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 2025.10.23 23:52:15.925991 [ 4108 ] {a5b6352c-ee38-41dc-a8ab-7b1e00c8db60} executeQuery: Code: 42. DB::Exception: Nullable data type family must have exactly one argument - nested type: In scope SELECT CAST(0, 'Nullable'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43688) (comment: 00540_bad_data_types.sh) (in query: SELECT CAST(0 AS Nullable)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:100: DB::create(std::shared_ptr const&) @ 0x0000000016e94b00 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000016e3f8c4 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000016e5a0e7 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x0000000016e59c3b 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:31: DB::DataTypeFactory::get(String const&) const @ 0x0000000016e576a1 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761d46a 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 2025.10.23 23:52:15.927171 [ 4108 ] {a5b6352c-ee38-41dc-a8ab-7b1e00c8db60} TCPHandler: Code: 42. DB::Exception: Nullable data type family must have exactly one argument - nested type: In scope SELECT CAST(0, 'Nullable'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/DataTypes/DataTypeNullable.cpp:100: DB::create(std::shared_ptr const&) @ 0x0000000016e94b00 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000016e3f8c4 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000016e5a0e7 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x0000000016e59c3b 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:31: DB::DataTypeFactory::get(String const&) const @ 0x0000000016e576a1 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761d46a 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 2025.10.23 23:52:16.272660 [ 2758 ] {} RefreshTask: Refresh view test_13.c failed (attempt 1/1): Code: 60. DB::Exception: Unknown table expression identifier 'test_13.src' in scope SELECT * FROM test_13.src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d594c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996bc 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc2d4c 12. ./build_docker/./src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x00000000192bb549 13. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:380: DB::RefreshTask::executeRefreshUnlocked(bool) @ 0x0000000019ff6028 14. ./contrib/llvm-project/libcxx/include/__mutex_base:207: DB::RefreshTask::refreshTask() @ 0x0000000019ff46e8 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019ff7522 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:52:16.782530 [ 4108 ] {36298429-4dce-4a04-8727-bcccdb0af45f} executeQuery: Code: 53. DB::Exception: CAST AS Tuple can only be performed between tuple types or from String. Left type: UInt8, right type: Tuple(): In scope SELECT CAST(0, 'Tuple'). (TYPE_MISMATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43708) (comment: 00540_bad_data_types.sh) (in query: SELECT CAST(0 AS Tuple)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::(anonymous namespace)::FunctionCast::createTupleWrapper(std::shared_ptr const&, DB::DataTypeTuple const*) const @ 0x000000000777f6ac 5. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000077644b6 6. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x0000000007761a24 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3444: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2cea 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 28. __tsan_thread_start_func @ 0x000000000758df2f 29. ? @ 0x00007f7c69445ac3 30. ? @ 0x00007f7c694d7850 2025.10.23 23:52:16.784265 [ 4108 ] {36298429-4dce-4a04-8727-bcccdb0af45f} TCPHandler: Code: 53. DB::Exception: CAST AS Tuple can only be performed between tuple types or from String. Left type: UInt8, right type: Tuple(): In scope SELECT CAST(0, 'Tuple'). (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::(anonymous namespace)::FunctionCast::createTupleWrapper(std::shared_ptr const&, DB::DataTypeTuple const*) const @ 0x000000000777f6ac 5. DB::(anonymous namespace)::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000077644b6 6. DB::(anonymous namespace)::FunctionCast::prepare(std::vector> const&) const @ 0x0000000007761a24 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3444: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2cea 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 28. __tsan_thread_start_func @ 0x000000000758df2f 29. ? @ 0x00007f7c69445ac3 30. ? @ 0x00007f7c694d7850 2025.10.23 23:52:17.011596 [ 2728 ] {} RefreshTask: Refresh view test_13.c failed (attempt 1/1): Code: 60. DB::Exception: Unknown table expression identifier 'test_13.src' in scope SELECT * FROM test_13.src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d594c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996bc 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc2d4c 12. ./build_docker/./src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x00000000192bb549 13. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:380: DB::RefreshTask::executeRefreshUnlocked(bool) @ 0x0000000019ff6028 14. ./contrib/llvm-project/libcxx/include/__mutex_base:207: DB::RefreshTask::refreshTask() @ 0x0000000019ff46e8 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019ff7522 16. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 18. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:52:17.926386 [ 4108 ] {90e6554c-90cf-43ed-a347-0f41afb74e0f} executeQuery: Code: 42. DB::Exception: FixedString data type family must have exactly one argument - size in bytes: In scope SELECT CAST(0, 'FixedString'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43732) (comment: 00540_bad_data_types.sh) (in query: SELECT CAST(0 AS FixedString)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/DataTypes/DataTypeFixedString.cpp:50: DB::create(std::shared_ptr const&) @ 0x0000000016e607cc 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000016e3f8c4 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000016e5a0e7 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x0000000016e59c3b 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:31: DB::DataTypeFactory::get(String const&) const @ 0x0000000016e576a1 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761d46a 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 2025.10.23 23:52:17.927898 [ 4108 ] {90e6554c-90cf-43ed-a347-0f41afb74e0f} TCPHandler: Code: 42. DB::Exception: FixedString data type family must have exactly one argument - size in bytes: In scope SELECT CAST(0, 'FixedString'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/DataTypes/DataTypeFixedString.cpp:50: DB::create(std::shared_ptr const&) @ 0x0000000016e607cc 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000016e3f8c4 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000016e5a0e7 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x0000000016e59c3b 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:31: DB::DataTypeFactory::get(String const&) const @ 0x0000000016e576a1 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761d46a 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 2025.10.23 23:52:18.850181 [ 4108 ] {ebfd941b-4e0c-446e-a1d6-b8c5382006fc} executeQuery: Code: 92. DB::Exception: Enum data type cannot be empty: In scope SELECT CAST(0, 'Enum'). (EMPTY_DATA_PASSED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43766) (comment: 00540_bad_data_types.sh) (in query: SELECT CAST(0 AS Enum)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/DataTypes/DataTypeEnum.cpp:288: DB::create(std::shared_ptr const&) @ 0x0000000016e4fa71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000016e3f8c4 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000016e5a0e7 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x0000000016e59c3b 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:31: DB::DataTypeFactory::get(String const&) const @ 0x0000000016e576a1 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761d46a 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 2025.10.23 23:52:18.852187 [ 4108 ] {ebfd941b-4e0c-446e-a1d6-b8c5382006fc} TCPHandler: Code: 92. DB::Exception: Enum data type cannot be empty: In scope SELECT CAST(0, 'Enum'). (EMPTY_DATA_PASSED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/DataTypes/DataTypeEnum.cpp:288: DB::create(std::shared_ptr const&) @ 0x0000000016e4fa71 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000016e3f8c4 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000016e5a0e7 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x0000000016e59c3b 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:31: DB::DataTypeFactory::get(String const&) const @ 0x0000000016e576a1 9. DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x000000000761d46a 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 2025.10.23 23:52:20.425085 [ 4108 ] {ad9930ba-e70b-4b44-88eb-2a09aa35c258} executeQuery: Code: 59. DB::Exception: Invalid type for filter in WHERE: String. In query SELECT * FROM system.one WHERE toString(dummy). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50610) (comment: 00540_bad_data_types.sh) (in query: SELECT * FROM system.one WHERE toString(dummy)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x00000000169c972c 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000017511a86 5. ./contrib/llvm-project/libcxx/include/vector:1501: DB::validateFilters(std::shared_ptr const&) @ 0x0000000017511819 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749b1eb 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 13. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 23. __tsan_thread_start_func @ 0x000000000758df2f 24. ? @ 0x00007f7c69445ac3 25. ? @ 0x00007f7c694d7850 2025.10.23 23:52:20.427306 [ 4108 ] {ad9930ba-e70b-4b44-88eb-2a09aa35c258} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in WHERE: String. In query SELECT * FROM system.one WHERE toString(dummy). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x00000000169c972c 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000017511a86 5. ./contrib/llvm-project/libcxx/include/vector:1501: DB::validateFilters(std::shared_ptr const&) @ 0x0000000017511819 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749b1eb 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 13. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 23. __tsan_thread_start_func @ 0x000000000758df2f 24. ? @ 0x00007f7c69445ac3 25. ? @ 0x00007f7c694d7850 2025.10.23 23:52:20.992361 [ 4108 ] {e2831204-59f5-4149-b89d-9349083c5c5f} executeQuery: Code: 59. DB::Exception: Invalid type for filter in WHERE: String. In query SELECT * FROM system.one WHERE toString(1). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50614) (comment: 00540_bad_data_types.sh) (in query: SELECT * FROM system.one WHERE toString(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x00000000169c972c 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000017511a86 5. ./contrib/llvm-project/libcxx/include/vector:1501: DB::validateFilters(std::shared_ptr const&) @ 0x0000000017511819 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749b1eb 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 13. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 23. __tsan_thread_start_func @ 0x000000000758df2f 24. ? @ 0x00007f7c69445ac3 25. ? @ 0x00007f7c694d7850 2025.10.23 23:52:20.994067 [ 4108 ] {e2831204-59f5-4149-b89d-9349083c5c5f} TCPHandler: Code: 59. DB::Exception: Invalid type for filter in WHERE: String. In query SELECT * FROM system.one WHERE toString(1). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x00000000169c972c 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000017511a86 5. ./contrib/llvm-project/libcxx/include/vector:1501: DB::validateFilters(std::shared_ptr const&) @ 0x0000000017511819 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749b1eb 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 13. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 23. __tsan_thread_start_func @ 0x000000000758df2f 24. ? @ 0x00007f7c69445ac3 25. ? @ 0x00007f7c694d7850 2025.10.23 23:52:22.336721 [ 2687 ] {83fd2aa3-2d8b-4714-b9dd-caa9c15af941} executeQuery: Code: 59. DB::Exception: Illegal type UInt16 of column for constant filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50616) (comment: 00540_bad_data_types.sh) (in query: SELECT * FROM system.one WHERE 256), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Columns/FilterDescription.cpp:0: DB::ConstantFilterDescription::ConstantFilterDescription(DB::IColumn const&) @ 0x000000001908ce5f 5. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:54: DB::(anonymous namespace)::analyzeFilter(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::ActionsChain&) @ 0x0000000017e2dfe7 6. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:0: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x0000000017e22b57 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:515: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcc661 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:52:22.339453 [ 2687 ] {83fd2aa3-2d8b-4714-b9dd-caa9c15af941} TCPHandler: Code: 59. DB::Exception: Illegal type UInt16 of column for constant filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Columns/FilterDescription.cpp:0: DB::ConstantFilterDescription::ConstantFilterDescription(DB::IColumn const&) @ 0x000000001908ce5f 5. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:54: DB::(anonymous namespace)::analyzeFilter(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::ActionsChain&) @ 0x0000000017e2dfe7 6. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:0: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x0000000017e22b57 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:515: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcc661 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:52:22.907650 [ 2687 ] {986f27b8-fd49-45b7-ae1a-8db3d7bfd025} executeQuery: Code: 59. DB::Exception: Illegal type Int8 of column for constant filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50636) (comment: 00540_bad_data_types.sh) (in query: SELECT * FROM system.one WHERE -1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Columns/FilterDescription.cpp:0: DB::ConstantFilterDescription::ConstantFilterDescription(DB::IColumn const&) @ 0x000000001908ce5f 5. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:54: DB::(anonymous namespace)::analyzeFilter(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::ActionsChain&) @ 0x0000000017e2dfe7 6. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:0: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x0000000017e22b57 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:515: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcc661 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:52:22.909561 [ 2687 ] {986f27b8-fd49-45b7-ae1a-8db3d7bfd025} TCPHandler: Code: 59. DB::Exception: Illegal type Int8 of column for constant filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Columns/FilterDescription.cpp:0: DB::ConstantFilterDescription::ConstantFilterDescription(DB::IColumn const&) @ 0x000000001908ce5f 5. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:54: DB::(anonymous namespace)::analyzeFilter(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::ActionsChain&) @ 0x0000000017e2dfe7 6. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:0: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x0000000017e22b57 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:515: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcc661 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:52:23.467910 [ 4108 ] {7822b228-8cdd-4e9c-8ec9-dc1d3e09d9a1} executeQuery: Code: 59. DB::Exception: Illegal type Nullable(UInt16) of column for constant filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50664) (comment: 00540_bad_data_types.sh) (in query: SELECT * FROM system.one WHERE CAST(256 AS Nullable(UInt16))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Columns/FilterDescription.cpp:0: DB::ConstantFilterDescription::ConstantFilterDescription(DB::IColumn const&) @ 0x000000001908ce5f 5. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:54: DB::(anonymous namespace)::analyzeFilter(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::ActionsChain&) @ 0x0000000017e2dfe7 6. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:0: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x0000000017e22b57 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:515: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcc661 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:52:23.469354 [ 4108 ] {7822b228-8cdd-4e9c-8ec9-dc1d3e09d9a1} TCPHandler: Code: 59. DB::Exception: Illegal type Nullable(UInt16) of column for constant filter. Must be UInt8 or Nullable(UInt8). (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Columns/FilterDescription.cpp:0: DB::ConstantFilterDescription::ConstantFilterDescription(DB::IColumn const&) @ 0x000000001908ce5f 5. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:54: DB::(anonymous namespace)::analyzeFilter(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::ActionsChain&) @ 0x0000000017e2dfe7 6. ./build_docker/./src/Planner/PlannerExpressionAnalysis.cpp:0: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x0000000017e22b57 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:515: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcc661 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:52:34.320281 [ 2687 ] {8980aced-ac9c-42cf-a866-dd2c1d2606d4} executeQuery: Code: 43. DB::Exception: First argument of function randomStringUTF8 must have numeric type: In scope SELECT randomStringUTF8('string'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:44738) (comment: 01278_random_string_utf8.sql) (in query: SELECT randomStringUTF8('string');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::(anonymous namespace)::FunctionRandomStringUTF8::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e04492b 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007614924 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.23 23:52:34.321473 [ 2687 ] {8980aced-ac9c-42cf-a866-dd2c1d2606d4} TCPHandler: Code: 43. DB::Exception: First argument of function randomStringUTF8 must have numeric type: In scope SELECT randomStringUTF8('string'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::(anonymous namespace)::FunctionRandomStringUTF8::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e04492b 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007614924 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.23 23:52:35.918337 [ 2687 ] {0146748a-b980-4587-b464-d19d0e34efd5} executeQuery: Code: 215. DB::Exception: Column mn is not under aggregate function and not in GROUP BY keys. In query SELECT n, number + 5 AS inter FROM (SELECT toFloat32(number % 10) AS n, number, number * 2 AS mn FROM numbers(10) WHERE (number % 3) = 1) GROUP BY n, inter ORDER BY n ASC WITH FILL FROM 0 TO 5.51 STEP 0.5 INTERPOLATE ( inter AS mn * 2 ). (NOT_AN_AGGREGATE) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:44780) (comment: 03155_analyzer_interpolate.sql) (in query: SELECT n, number+5 AS inter FROM ( -- { serverError NOT_AN_AGGREGATE } SELECT toFloat32(number % 10) AS n, number, number*2 AS mn FROM numbers(10) WHERE number % 3 = 1 ) GROUP BY n, inter ORDER BY n WITH FILL FROM 0 TO 5.51 STEP 0.5 INTERPOLATE (inter AS mn * 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017513d55 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017513957 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017513957 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017513957 8. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017513957 9. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000001751336e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.23 23:52:35.920043 [ 2687 ] {0146748a-b980-4587-b464-d19d0e34efd5} TCPHandler: Code: 215. DB::Exception: Column mn is not under aggregate function and not in GROUP BY keys. In query SELECT n, number + 5 AS inter FROM (SELECT toFloat32(number % 10) AS n, number, number * 2 AS mn FROM numbers(10) WHERE (number % 3) = 1) GROUP BY n, inter ORDER BY n ASC WITH FILL FROM 0 TO 5.51 STEP 0.5 INTERPOLATE ( inter AS mn * 2 ). (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017513d55 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017513957 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017513957 7. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017513957 8. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x0000000017513957 9. ./build_docker/./src/Analyzer/ValidationUtils.cpp:0: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000001751336e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000001749b209 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.23 23:52:50.117462 [ 2687 ] {d8d992a1-ef25-4ac5-8ef6-ba306255cb06} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE t2; to attach existing table or CREATE TABLE t2
; to create new table or ATTACH TABLE t2 FROM '/path/to/data/'
; to create new table and attach data. 2025.10.23 23:52:50.882497 [ 2687 ] {d8d992a1-ef25-4ac5-8ef6-ba306255cb06} executeQuery: Code: 253. DB::Exception: There already is an active replica with this replica path /clickhouse/tables/fzTWXVqLfS/f703d901-1b2c-47a6-acd2-839dea68e2cb/replicas/r1. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:41880) (comment: 03013_forbid_attach_table_if_active_replica_already_exists.sh) (in query: attach table fzTWXVqLfS.t2 UUID 'f703d901-1b2c-47a6-acd2-839dea68e2cb' (a Int) engine=ReplicatedMergeTree('/clickhouse/tables/{database}/f703d901-1b2c-47a6-acd2-839dea68e2cb', '{replica}') order by tuple() SETTINGS index_granularity = 8192), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:414: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000019343436 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000019e4f587 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a2e3 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.23 23:52:50.942109 [ 2687 ] {d8d992a1-ef25-4ac5-8ef6-ba306255cb06} TCPHandler: Code: 253. DB::Exception: There already is an active replica with this replica path /clickhouse/tables/fzTWXVqLfS/f703d901-1b2c-47a6-acd2-839dea68e2cb/replicas/r1. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:414: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000019343436 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000019e4f587 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a2e3 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.23 23:52:53.215387 [ 4108 ] {a61f9bbb-1066-4228-bcd3-415c3e3a571c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:41930) (comment: 01702_rewrite_avg_for_algebraic_optimization.sql) (in query: SELECT 'value: ', avg(number - 2) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:52:53.219213 [ 4108 ] {a61f9bbb-1066-4228-bcd3-415c3e3a571c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:52:55.619099 [ 4108 ] {64bb3582-bc58-4cc1-aaea-82f9932e6a82} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=746, jobs=721). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:41952) (comment: 01605_dictinct_two_level.sql) (in query: INSERT INTO distinct_two_level SELECT 1546300800000, 'test.com', concat('foo', toString(number % 10000)) from numbers(10000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f2d53 8. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000001a1ec1ec 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:52:55.621029 [ 4108 ] {64bb3582-bc58-4cc1-aaea-82f9932e6a82} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=746, jobs=721). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f2d53 8. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000001a1ec1ec 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:52:56.971482 [ 2687 ] {2d90e52b-34ce-4595-bded-9b077f70c3c6} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT toStartOfInterval(toDateTime64('\0930-12-12 12:12:12.1234567', 3), toIntervalNanosecond(1024)). (DECIMAL_OVERFLOW) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:41974) (comment: 02269_to_start_of_interval_overflow.sql) (in query: select toStartOfInterval(toDateTime64('\0930-12-12 12:12:12.1234567', 3), toIntervalNanosecond(1024));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. DB::ToStartOfInterval<(DB::IntervalKind::Kind)0>::execute(long, long, DateLUTImpl const&, long) @ 0x000000000e47bf81 5. COW::immutable_ptr DB::FunctionToStartOfInterval::execute, DB::DataTypeDateTime64, (DB::IntervalKind::Kind)0>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, long, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x000000000e479b5d 6. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x000000000e477e99 7. DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long) const @ 0x000000000e477a2a 8. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e4770e1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 27. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 2025.10.23 23:52:56.972657 [ 2687 ] {2d90e52b-34ce-4595-bded-9b077f70c3c6} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT toStartOfInterval(toDateTime64('\0930-12-12 12:12:12.1234567', 3), toIntervalNanosecond(1024)). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. DB::ToStartOfInterval<(DB::IntervalKind::Kind)0>::execute(long, long, DateLUTImpl const&, long) @ 0x000000000e47bf81 5. COW::immutable_ptr DB::FunctionToStartOfInterval::execute, DB::DataTypeDateTime64, (DB::IntervalKind::Kind)0>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, long, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x000000000e479b5d 6. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x000000000e477e99 7. DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long) const @ 0x000000000e477a2a 8. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e4770e1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 27. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 2025.10.23 23:52:56.991991 [ 2687 ] {7ac6f67e-b243-409b-b37d-5745949e306c} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT toDateTime64(-9223372036854775808, 1048575, toIntervalNanosecond(9223372036854775806), NULL), toStartOfInterval(toDateTime64(toIntervalNanosecond(toIntervalNanosecond(257), toDateTime64(toStartOfInterval(toDateTime64(NULL)))), '', 100), toIntervalNanosecond(toStartOfInterval(toDateTime64(toIntervalNanosecond(NULL), NULL)), -1)), toStartOfInterval(toDateTime64('\0930-12-12 12:12:12.1234567', 3), toIntervalNanosecond(1024)). (DECIMAL_OVERFLOW) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:41974) (comment: 02269_to_start_of_interval_overflow.sql) (in query: SELECT toDateTime64(-9223372036854775808, 1048575, toIntervalNanosecond(9223372036854775806), NULL), toStartOfInterval(toDateTime64(toIntervalNanosecond(toIntervalNanosecond(257), toDateTime64(toStartOfInterval(toDateTime64(NULL)))), '', 100), toIntervalNanosecond(toStartOfInterval(toDateTime64(toIntervalNanosecond(NULL), NULL)), -1)), toStartOfInterval(toDateTime64('\0930-12-12 12:12:12.1234567', 3), toIntervalNanosecond(1024));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. DB::ToStartOfInterval<(DB::IntervalKind::Kind)0>::execute(long, long, DateLUTImpl const&, long) @ 0x000000000e47bf81 5. COW::immutable_ptr DB::FunctionToStartOfInterval::execute, DB::DataTypeDateTime64, (DB::IntervalKind::Kind)0>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, long, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x000000000e479b5d 6. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x000000000e477e99 7. DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long) const @ 0x000000000e477a2a 8. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e4770e1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 27. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 2025.10.23 23:52:56.993274 [ 2687 ] {7ac6f67e-b243-409b-b37d-5745949e306c} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT toDateTime64(-9223372036854775808, 1048575, toIntervalNanosecond(9223372036854775806), NULL), toStartOfInterval(toDateTime64(toIntervalNanosecond(toIntervalNanosecond(257), toDateTime64(toStartOfInterval(toDateTime64(NULL)))), '', 100), toIntervalNanosecond(toStartOfInterval(toDateTime64(toIntervalNanosecond(NULL), NULL)), -1)), toStartOfInterval(toDateTime64('\0930-12-12 12:12:12.1234567', 3), toIntervalNanosecond(1024)). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. DB::ToStartOfInterval<(DB::IntervalKind::Kind)0>::execute(long, long, DateLUTImpl const&, long) @ 0x000000000e47bf81 5. COW::immutable_ptr DB::FunctionToStartOfInterval::execute, DB::DataTypeDateTime64, (DB::IntervalKind::Kind)0>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, long, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x000000000e479b5d 6. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x000000000e477e99 7. DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long) const @ 0x000000000e477a2a 8. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e4770e1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 27. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 2025.10.23 23:53:02.526908 [ 3112 ] {} RefreshTask: Refresh view test_13.e failed (attempt 1/1): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 15. ./src/Interpreters/InterpreterCreateQuery.h:29: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x0000000017c5085a 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1535: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4da81 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 18. ./build_docker/./src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x00000000192bab92 19. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:380: DB::RefreshTask::executeRefreshUnlocked(bool) @ 0x0000000019ff6028 20. ./contrib/llvm-project/libcxx/include/__mutex_base:207: DB::RefreshTask::refreshTask() @ 0x0000000019ff46e8 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019ff7522 22. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 24. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:04.503586 [ 3310 ] {40faa80e-86c4-4769-8e34-1aa660c156dc::202510_1_11_2_15} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:04.504341 [ 3310 ] {40faa80e-86c4-4769-8e34-1aa660c156dc::202510_1_11_2_15} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:04.512449 [ 3314 ] {40faa80e-86c4-4769-8e34-1aa660c156dc::202510_14_14_0_15} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:04.512984 [ 3314 ] {40faa80e-86c4-4769-8e34-1aa660c156dc::202510_14_14_0_15} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:04.604461 [ 3313 ] {40faa80e-86c4-4769-8e34-1aa660c156dc::202510_14_14_0_15} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column user): (while reading from part /var/lib/clickhouse/store/40f/40faa80e-86c4-4769-8e34-1aa660c156dc/202510_14_14_0/ in table system.session_log (40faa80e-86c4-4769-8e34-1aa660c156dc) located on disk default of type local, from mark 0 with max_rows_to_read = 66): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:04.607857 [ 3309 ] {40faa80e-86c4-4769-8e34-1aa660c156dc::202510_13_13_0_15} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:04.608597 [ 3309 ] {40faa80e-86c4-4769-8e34-1aa660c156dc::202510_13_13_0_15} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:04.650335 [ 3320 ] {40faa80e-86c4-4769-8e34-1aa660c156dc::202510_1_11_2_15} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column user): (while reading from part /var/lib/clickhouse/store/40f/40faa80e-86c4-4769-8e34-1aa660c156dc/202510_1_11_2/ in table system.session_log (40faa80e-86c4-4769-8e34-1aa660c156dc) located on disk default of type local, from mark 0 with max_rows_to_read = 1289): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:04.689271 [ 4108 ] {7837b0c0-4954-41f3-99e4-242e15da22b6} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_15.txt' with part '202510_1_11_2' reason: 'Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:46436) (comment: 02834_remote_session_log.sh) (in query: DELETE FROM system.session_log WHERE user = '02834_USER_8740'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000019ba6454 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000019ba635c 5. ./src/Common/SharedLockGuard.h:19: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000019e594c0 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000019e5a922 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c29b97 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 9. ./src/Interpreters/InterpreterAlterQuery.h:18: DB::InterpreterDeleteQuery::execute()::$_0::operator()() const @ 0x00000000182c7a44 10. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:0: DB::InterpreterDeleteQuery::execute() @ 0x00000000182c5b53 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.23 23:53:04.690340 [ 4108 ] {7837b0c0-4954-41f3-99e4-242e15da22b6} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_15.txt' with part '202510_1_11_2' reason: 'Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000019ba6454 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000019ba635c 5. ./src/Common/SharedLockGuard.h:19: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000019e594c0 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000019e5a922 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c29b97 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 9. ./src/Interpreters/InterpreterAlterQuery.h:18: DB::InterpreterDeleteQuery::execute()::$_0::operator()() const @ 0x00000000182c7a44 10. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:0: DB::InterpreterDeleteQuery::execute() @ 0x00000000182c5b53 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.23 23:53:04.917208 [ 3313 ] {40faa80e-86c4-4769-8e34-1aa660c156dc::202510_14_14_0_15} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column user): (while reading from part /var/lib/clickhouse/store/40f/40faa80e-86c4-4769-8e34-1aa660c156dc/202510_14_14_0/ in table system.session_log (40faa80e-86c4-4769-8e34-1aa660c156dc) located on disk default of type local, from mark 0 with max_rows_to_read = 66): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000016d64235 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d65c54 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d661ce 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fe0f1e 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationNullable::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016fd4ec5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bcd448 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bee90e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a98c8ea 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 27. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 28. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:04.917642 [ 3320 ] {40faa80e-86c4-4769-8e34-1aa660c156dc::202510_1_11_2_15} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column user): (while reading from part /var/lib/clickhouse/store/40f/40faa80e-86c4-4769-8e34-1aa660c156dc/202510_1_11_2/ in table system.session_log (40faa80e-86c4-4769-8e34-1aa660c156dc) located on disk default of type local, from mark 0 with max_rows_to_read = 1289): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000016d64235 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d65c54 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d661ce 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fe0f1e 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::SerializationNullable::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016fd4ec5 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bcd448 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bee90e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a98c8ea 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 27. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 28. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:05.036292 [ 3314 ] {40faa80e-86c4-4769-8e34-1aa660c156dc::202510_13_13_0_15} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:05.037041 [ 3314 ] {40faa80e-86c4-4769-8e34-1aa660c156dc::202510_13_13_0_15} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:05.042250 [ 3309 ] {40faa80e-86c4-4769-8e34-1aa660c156dc::202510_14_14_0_15} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:05.043166 [ 3309 ] {40faa80e-86c4-4769-8e34-1aa660c156dc::202510_14_14_0_15} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:05.786739 [ 3320 ] {40faa80e-86c4-4769-8e34-1aa660c156dc::202510_14_14_0_15} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:05.787537 [ 3320 ] {40faa80e-86c4-4769-8e34-1aa660c156dc::202510_14_14_0_15} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:07.704184 [ 3309 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4a6404b7-e320-48a8-83da-1f6d279d54c0::202510_1_30_6}: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fa36f06 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000000fa34b23 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000000f9c38f7 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000000fa6ada2 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x0000000019ea2870 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b2a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:10.263487 [ 3316 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {34e0b00e-fe5a-47d8-af0c-3ae1d30a34d1::202510_1_71_14}: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fa36f06 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000000fa34b23 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000000f9c38f7 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000000fa6ada2 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x0000000019ea2870 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b2a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:10.773753 [ 2687 ] {6892b4d8-6b7e-478f-8d41-b871886e799b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=752, jobs=722). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:48100) (comment: 02834_remote_session_log.sh) (in query: SELECT count(*) FROM system.session_log WHERE user = '02834_USER_8740' and client_address = toIPv6('::')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:53:10.777021 [ 2687 ] {6892b4d8-6b7e-478f-8d41-b871886e799b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=752, jobs=722). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:53:11.406394 [ 2687 ] {9a4b6155-b82f-4b58-872c-2dbe6c1ce5df} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:48124) (comment: 02834_remote_session_log.sh) (in query: SELECT count(*) FROM system.session_log WHERE user = '02834_USER_8740' and type = 'LoginFailure'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c63e3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.23 23:53:11.409074 [ 2687 ] {9a4b6155-b82f-4b58-872c-2dbe6c1ce5df} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c63e3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.23 23:53:18.242559 [ 2687 ] {74e9a48b-48ec-4165-a868-fd41180d13f0} executeQuery: Code: 174. DB::Exception: Cyclic aliases for identifier 'b'. In scope SELECT a + 1 AS b, b + 1 AS a FROM (SELECT 10 AS a). (CYCLIC_ALIASES) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:48240) (comment: 00818_alias_bug_4110.sql) (in query: select a + 1 as b, b + 1 as a from (select 10 as a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b2b45 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b350f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1fee 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bd4a8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b251c 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b350f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1fee 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bd4a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 2025.10.23 23:53:18.244275 [ 2687 ] {74e9a48b-48ec-4165-a868-fd41180d13f0} TCPHandler: Code: 174. DB::Exception: Cyclic aliases for identifier 'b'. In scope SELECT a + 1 AS b, b + 1 AS a FROM (SELECT 10 AS a). (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b2b45 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b350f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1fee 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bd4a8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b251c 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b350f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1fee 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bd4a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 2025.10.23 23:53:18.634629 [ 2687 ] {07babcdc-24c2-4916-a509-98dc531fcc28} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'a' in scope SELECT 10 AS a, a + 1 AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:48240) (comment: 00818_alias_bug_4110.sql) (in query: select 10 as a, a + 1 as a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bd4a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.23 23:53:18.725390 [ 2687 ] {07babcdc-24c2-4916-a509-98dc531fcc28} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'a' in scope SELECT 10 AS a, a + 1 AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bd4a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.23 23:53:19.021582 [ 3182 ] {} RefreshTask: Refresh view test_13.e failed (attempt 1/1): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 15. ./src/Interpreters/InterpreterCreateQuery.h:29: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x0000000017c5085a 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1535: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4da81 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 18. ./build_docker/./src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x00000000192bab92 19. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:380: DB::RefreshTask::executeRefreshUnlocked(bool) @ 0x0000000019ff6028 20. ./contrib/llvm-project/libcxx/include/__mutex_base:207: DB::RefreshTask::refreshTask() @ 0x0000000019ff46e8 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019ff7522 22. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 24. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:19.040747 [ 4099 ] {c06acc23-924a-4ce0-99e4-c6e7a52908e3} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:39142) (comment: 01890_jit_aggregation_function_sum_long.sql) (in query: DROP DATABASE IF EXISTS test_49vcnmyq ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:53:19.042401 [ 4099 ] {c06acc23-924a-4ce0-99e4-c6e7a52908e3} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:19.394599 [ 2687 ] {04ec1c43-5f67-40b6-b11d-048393c16d6d} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'a' in scope WITH 10 AS a SELECT a AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:48240) (comment: 00818_alias_bug_4110.sql) (in query: with 10 as a select a as a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:53:19.395834 [ 2687 ] {04ec1c43-5f67-40b6-b11d-048393c16d6d} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'a' in scope WITH 10 AS a SELECT a AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:53:19.405417 [ 2687 ] {a7e395b8-6c1a-4aa3-8ca6-1f095673289c} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'a' in scope WITH 10 AS a SELECT a + 1 AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:48240) (comment: 00818_alias_bug_4110.sql) (in query: with 10 as a select a + 1 as a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bd4a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.23 23:53:19.406136 [ 2687 ] {a7e395b8-6c1a-4aa3-8ca6-1f095673289c} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'a' in scope WITH 10 AS a SELECT a + 1 AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bd4a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.23 23:53:19.996344 [ 2687 ] {cf57805d-a424-4eff-b4c6-868ac1bd3ee4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=752, jobs=722). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:49086) (comment: 00974_distributed_join_on.sql) (in query: SELECT 1 FROM distributed_table1 AS t1 GLOBAL JOIN distributed_table2 AS t2 ON t1.a = t2.c LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:53:19.997839 [ 2687 ] {cf57805d-a424-4eff-b4c6-868ac1bd3ee4} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=752, jobs=722). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:53:24.173718 [ 2687 ] {d07fee51-f79d-4c60-ada7-1e14d8abb9db} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:49126) (comment: 02366_kql_summarize.sql) (in query: Customers | summarize f_list = make_set(Education, 2) by Occupation | sort by Occupation;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:53:24.175765 [ 2687 ] {d07fee51-f79d-4c60-ada7-1e14d8abb9db} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:53:25.221051 [ 3015 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:31.500247 [ 2687 ] {eb63c96a-abbc-473e-a41c-aeb491f33f9c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45234) (comment: 03039_dynamic_versioned_collapsing_merge_tree.sh) (in query: insert into test select number, -1, number >= 75000 ? 2 : 1, 'str_' || toString(number) from numbers(50000, 100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f356a 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:53:31.536316 [ 2687 ] {eb63c96a-abbc-473e-a41c-aeb491f33f9c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f356a 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:53:36.018249 [ 2747 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:37.464109 [ 3310 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {678af7ec-371a-476f-b893-c6848743a362::202510_1_35_7}: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fa36f06 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000000fa34b23 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000000f9c38f7 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000000fa6ada2 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x0000000019ea2870 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b2a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:41.701298 [ 2687 ] {90af55d5-3c2d-45a0-bc2d-9fb68249cfaf} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column d): (while reading from part /var/lib/clickhouse/store/760/760c3473-84fb-4e40-9d7c-6e0b8982bf0c/all_2_2_0/ in table test_7npck6lp.test (760c3473-84fb-4e40-9d7c-6e0b8982bf0c) located on disk default of type local, from mark 0 with max_rows_to_read = 8985): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36756) (comment: 03039_dynamic_versioned_collapsing_merge_tree.sh) (in query: select count(), dynamicType(d) from test group by dynamicType(d) order by count(), dynamicType(d)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d62f83 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d65385 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d655fe 16. DB::ReadBuffer::next() @ 0x0000000007b3717b 17. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b69ee3 18. ./contrib/llvm-project/libcxx/include/new:246: DB::SerializationDynamic::deserializeDynamicStructureStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) @ 0x0000000016f859f4 19. ./build_docker/./src/DataTypes/Serializations/SerializationDynamic.cpp:223: DB::SerializationDynamic::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000016f84ff8 20. ./contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeReaderWide::deserializePrefix(std::shared_ptr const&, DB::NameAndTypePair const&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000019bfcfe9 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::MergeTreeReaderWide::prefetchForColumn(Priority, DB::NameAndTypePair const&, std::shared_ptr const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000019bfa6f9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:109: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000019bfa448 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bfaeba 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 26. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 27. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 28. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a98c8ea 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 31. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 2025.10.23 23:53:41.709718 [ 2687 ] {90af55d5-3c2d-45a0-bc2d-9fb68249cfaf} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column d): (while reading from part /var/lib/clickhouse/store/760/760c3473-84fb-4e40-9d7c-6e0b8982bf0c/all_2_2_0/ in table test_7npck6lp.test (760c3473-84fb-4e40-9d7c-6e0b8982bf0c) located on disk default of type local, from mark 0 with max_rows_to_read = 8985): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d62f83 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d65385 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d655fe 16. DB::ReadBuffer::next() @ 0x0000000007b3717b 17. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b69ee3 18. ./contrib/llvm-project/libcxx/include/new:246: DB::SerializationDynamic::deserializeDynamicStructureStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) @ 0x0000000016f859f4 19. ./build_docker/./src/DataTypes/Serializations/SerializationDynamic.cpp:223: DB::SerializationDynamic::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000016f84ff8 20. ./contrib/llvm-project/libcxx/include/vector:438: DB::MergeTreeReaderWide::deserializePrefix(std::shared_ptr const&, DB::NameAndTypePair const&, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000019bfcfe9 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:593: DB::MergeTreeReaderWide::prefetchForColumn(Priority, DB::NameAndTypePair const&, std::shared_ptr const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&) @ 0x0000000019bfa6f9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:109: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000019bfa448 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bfaeba 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 26. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 27. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 28. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a98c8ea 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 30. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 31. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 2025.10.23 23:53:48.145808 [ 5110 ] {} test_1.table_for_freeze (d13a25dc-aaf8-4db9-821f-f36e3f752969): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.10.23 23:53:48.660303 [ 5110 ] {} DatabaseCatalog: Cannot drop table test_1.table_for_freeze (d13a25dc-aaf8-4db9-821f-f36e3f752969). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199db57d 9. ./contrib/llvm-project/libcxx/include/__hash_table:935: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x00000000199d8d27 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x00000000199e0e99 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:317: DB::StorageMergeTree::drop() @ 0x0000000019e54b04 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000176a79f9 13. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000176b3544 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000160e3d18 15. ./contrib/llvm-project/libcxx/include/future:1694: std::__packaged_task_func>, std::function>::operator()(std::function&&, Priority)::'lambda'(), std::allocator>, std::function>::operator()(std::function&&, Priority)::'lambda'()>, void ()>::operator()() @ 0x00000000160e3c1e 16. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000101feb95 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000160e4e4d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 23. __tsan_thread_start_func @ 0x000000000758df2f 24. ? @ 0x00007f7c69445ac3 25. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:53.660515 [ 3565 ] {44ceeb4d-cae6-4dc1-b1fc-88b3f6f1cc3e} executeQuery: Code: 60. DB::Exception: Could not find table: table_for_freeze. (UNKNOWN_TABLE) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:37080) (comment: 01417_freeze_partition_verbose.sh) (in query: ALTER TABLE table_for_freeze UNFREEZE PARTITION '7' WITH NAME 'test_01417_single_part_7_system'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2a671 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:53:53.661912 [ 3565 ] {44ceeb4d-cae6-4dc1-b1fc-88b3f6f1cc3e} TCPHandler: Code: 60. DB::Exception: Could not find table: table_for_freeze. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2a671 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:53:54.017933 [ 2722 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:53:58.456534 [ 4019 ] {8031c54f-8f58-47c0-9d1b-6bd8946d7488} executeQuery: Code: 57. DB::Exception: Table test_7npck6lp.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:37216) (comment: 03039_dynamic_versioned_collapsing_merge_tree.sh) (in query: CREATE TABLE test (`id` UInt64, `sign` Int8, `version` UInt8, `d` Dynamic) ENGINE = VersionedCollapsingMergeTree(sign, version) ORDER BY id SETTINGS min_rows_for_wide_part = 1, min_bytes_for_wide_part = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, index_granularity = 8128, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 73, min_bytes_for_full_part_storage = 331782649, compact_parts_max_bytes_to_buffer = 285985065, compact_parts_max_granules_to_buffer = 236, compact_parts_merge_max_bytes_to_prefetch_part = 23909647, merge_max_block_size = 8128, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 6988175974, min_merge_bytes_to_use_direct_io = 9007208752, index_granularity_bytes = 10485760, concurrent_part_removal_threshold = 51, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 75859, primary_key_compress_block_size = 48095), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:53:58.458233 [ 4019 ] {8031c54f-8f58-47c0-9d1b-6bd8946d7488} TCPHandler: Code: 57. DB::Exception: Table test_7npck6lp.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:54:02.903995 [ 2687 ] {e98c7712-6916-453d-8c87-88a628c9510b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:38406) (comment: 03039_dynamic_versioned_collapsing_merge_tree.sh) (in query: select count(), dynamicType(d) from test group by dynamicType(d) order by count(), dynamicType(d)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9bdbb2 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a967e00 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 28. __tsan_thread_start_func @ 0x000000000758df2f 29. ? @ 0x00007f7c69445ac3 30. ? @ 0x00007f7c694d7850 2025.10.23 23:54:02.909972 [ 2687 ] {e98c7712-6916-453d-8c87-88a628c9510b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9bdbb2 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a967e00 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 28. __tsan_thread_start_func @ 0x000000000758df2f 29. ? @ 0x00007f7c69445ac3 30. ? @ 0x00007f7c694d7850 2025.10.23 23:54:03.018442 [ 2961 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:03.120255 [ 2955 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:03.633223 [ 3565 ] {ddbac841-ce53-4d5a-afd9-97db8647b695} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 0.00 B (attempt to allocate chunk of 0 bytes), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:38382) (comment: 00962_visit_param_various.sql) (in query: SELECT sum(ignore(visitParamExtractRaw(concat('{"a":', reinterpretAsString(rand64())), 'a'))) FROM numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000000fa3705c 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa361e0 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa35c1e 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:85: CurrentMemoryTracker::check() @ 0x000000000f9c34a8 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1710: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x00000000177410c3 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1497: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000001774dee5 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000001a671b9e 10. ./contrib/llvm-project/libcxx/include/vector:438: DB::AggregatingTransform::work() @ 0x000000001a66dd53 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 15. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:54:03.634559 [ 3565 ] {ddbac841-ce53-4d5a-afd9-97db8647b695} TCPHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 0.00 B (attempt to allocate chunk of 0 bytes), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000000fa3705c 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa361e0 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa35c1e 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:85: CurrentMemoryTracker::check() @ 0x000000000f9c34a8 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1710: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x00000000177410c3 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1497: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000001774dee5 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000001a671b9e 10. ./contrib/llvm-project/libcxx/include/vector:438: DB::AggregatingTransform::work() @ 0x000000001a66dd53 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 15. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 16. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:54:05.073097 [ 2920 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:08.201818 [ 2829 ] {} RefreshTask: Refresh view test_13.e failed (attempt 1/1): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 15. ./src/Interpreters/InterpreterCreateQuery.h:29: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x0000000017c5085a 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1535: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4da81 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 18. ./build_docker/./src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x00000000192bab92 19. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:380: DB::RefreshTask::executeRefreshUnlocked(bool) @ 0x0000000019ff6028 20. ./contrib/llvm-project/libcxx/include/__mutex_base:207: DB::RefreshTask::refreshTask() @ 0x0000000019ff46e8 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019ff7522 22. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 24. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:10.938303 [ 2687 ] {614caea7-ce90-43e4-aada-02d3fe372953} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:40628) (comment: 01736_null_as_default.sql) (in query: select * from test_enum;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:54:10.941552 [ 2687 ] {614caea7-ce90-43e4-aada-02d3fe372953} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:54:12.454561 [ 10385 ] {5aa60880-c034-42c7-817f-6e1369479123} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=752, jobs=722). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:40692) (comment: 00258_materializing_tuples.sql) (in query: select * from (select tuple(1) as a union all select tuple(1) as a) order by a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:54:12.461462 [ 10385 ] {5aa60880-c034-42c7-817f-6e1369479123} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=752, jobs=722). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:54:14.942112 [ 2687 ] {14da7b37-f7db-42a8-8523-faa23a6ebc08} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:40656) (comment: 02875_parallel_replicas_cluster_all_replicas.sql) (in query: SELECT count() > 0 FROM system.text_log WHERE query_id in (select query_id from system.query_log where current_database = currentDatabase() AND log_comment = '02875_190aed82-2423-413b-ad4c-24dcca50f65b') AND message LIKE '%Parallel reading from replicas is disabled for cluster%';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c63e3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.23 23:54:14.945827 [ 2687 ] {14da7b37-f7db-42a8-8523-faa23a6ebc08} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c63e3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.23 23:54:15.267614 [ 10419 ] {ffa76ac3-7dca-40b4-979f-68d0ac108782} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:40714) (comment: 01414_low_cardinality_nullable.sql) (in query: SELECT count() FROM lc_nullable WHERE has(u64, 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:54:15.269308 [ 10419 ] {ffa76ac3-7dca-40b4-979f-68d0ac108782} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:54:15.367640 [ 3313 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3391eeb9-30c2-4727-900d-ef688a8fcf48::202510_1_57_12}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:15.530073 [ 10385 ] {66441bdf-4143-4e04-8d23-e485294d90b3} Context: Server has databases (for example `02988_ordinary`) with Ordinary engine, which was deprecated. To convert this database to the new Atomic engine, create a flag /var/lib/clickhouse/flags/convert_ordinary_to_atomic and make sure that ClickHouse has write permission for it. Example: sudo touch '/var/lib/clickhouse/flags/convert_ordinary_to_atomic' && sudo chmod 666 '/var/lib/clickhouse/flags/convert_ordinary_to_atomic' 2025.10.23 23:54:19.163852 [ 3318 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {34e0b00e-fe5a-47d8-af0c-3ae1d30a34d1::202510_1_81_16}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:29.027941 [ 3319 ] {1d9f0283-8a52-495d-abd8-b38c806cf68b::all_1_1_1_2} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=752, jobs=723). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:29.472562 [ 2687 ] {15ba445d-72b0-4839-a2f9-b588f4787bfe} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_2.txt' with part 'all_1_1_1' reason: 'Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=752, jobs=723). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:34510) (comment: 02478_projection_with_group_by_alter.sql) (in query: -- update all columns used by proj_1 ALTER TABLE testing UPDATE c = c+1, d = d+2 WHERE True SETTINGS mutations_sync=2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000019ba6454 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000019ba635c 5. ./src/Common/SharedLockGuard.h:19: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000019e594c0 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000019e5a922 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c29b97 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:54:29.474570 [ 2687 ] {15ba445d-72b0-4839-a2f9-b588f4787bfe} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_2.txt' with part 'all_1_1_1' reason: 'Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=752, jobs=723). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000019ba6454 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000019ba635c 5. ./src/Common/SharedLockGuard.h:19: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000019e594c0 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000019e5a922 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c29b97 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:54:29.637208 [ 3319 ] {1d9f0283-8a52-495d-abd8-b38c806cf68b::all_1_1_1_2} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=752, jobs=723). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:213: DB::isStorageTouchedByMutations(std::shared_ptr, std::shared_ptr, std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000017ea8eaa 10. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2185: DB::MutateTask::prepare() @ 0x0000000019ca930b 11. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000019ca8475 12. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:0: DB::MutatePlainMergeTreeTask::executeStep() @ 0x0000000019ea4e1b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 14. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:30.452200 [ 10385 ] {2449489e-0010-470c-9d29-5473a242fc9a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:34376) (comment: 02735_parquet_encoder.sql) (in query: insert into function file(madness_02735.parquet) select * from madness_02735;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a53c6f5 8. ./build_docker/./src/Processors/Formats/Impl/ParquetBlockOutputFormat.cpp:0: DB::ParquetBlockOutputFormat::writeRowGroupInParallel(std::vector>) @ 0x000000001a53aed1 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::ParquetBlockOutputFormat::writeRowGroup(std::vector>) @ 0x000000001a538f44 10. ./build_docker/./src/Processors/Formats/Impl/ParquetBlockOutputFormat.cpp:0: DB::ParquetBlockOutputFormat::consume(DB::Chunk) @ 0x000000001a53712b 11. ./contrib/llvm-project/libcxx/include/vector:438: DB::IOutputFormat::write(DB::Block const&) @ 0x000000001a315796 12. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::StorageFileSink::consume(DB::Chunk&) @ 0x00000000191ee39a 13. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7de8ed 14. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a6a6806 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6a6578 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a6a5e75 17. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:54:30.456451 [ 10385 ] {2449489e-0010-470c-9d29-5473a242fc9a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a53c6f5 8. ./build_docker/./src/Processors/Formats/Impl/ParquetBlockOutputFormat.cpp:0: DB::ParquetBlockOutputFormat::writeRowGroupInParallel(std::vector>) @ 0x000000001a53aed1 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::ParquetBlockOutputFormat::writeRowGroup(std::vector>) @ 0x000000001a538f44 10. ./build_docker/./src/Processors/Formats/Impl/ParquetBlockOutputFormat.cpp:0: DB::ParquetBlockOutputFormat::consume(DB::Chunk) @ 0x000000001a53712b 11. ./contrib/llvm-project/libcxx/include/vector:438: DB::IOutputFormat::write(DB::Block const&) @ 0x000000001a315796 12. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::StorageFileSink::consume(DB::Chunk&) @ 0x00000000191ee39a 13. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7de8ed 14. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a6a6806 15. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6a6578 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a6a5e75 17. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:54:31.665506 [ 2687 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000001682a339 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175b6066 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175b675b 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a206a77 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1f6dd1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1eb38f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:54:32.049579 [ 3140 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:32.347566 [ 10936 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000001682a339 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175b6066 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175b675b 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a206a77 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1f6dd1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1eb38f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:54:32.789403 [ 10936 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000001682a339 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175b6066 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175b675b 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a206a77 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1f6dd1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1eb38f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:54:32.985286 [ 3314 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6e0ce121-7b71-4e14-a14f-c7c363eaab4f::202510_1_138_27}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:33.234522 [ 10936 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000001682a339 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175b6066 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175b675b 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a206a77 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1f6dd1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1eb38f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:54:33.635213 [ 10385 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000001682a339 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175b6066 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175b675b 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a206a77 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1f6dd1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1eb38f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:54:34.080297 [ 2687 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000001682a339 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175b6066 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175b675b 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a206a77 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1f6dd1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1eb38f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:54:34.521982 [ 2687 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000001682a339 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175b6066 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175b675b 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a206a77 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1f6dd1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1eb38f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:54:34.935182 [ 10385 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000001682a339 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175b6066 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175b675b 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a206a77 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1f6dd1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1eb38f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:54:40.637894 [ 10936 ] {bc28c6ea-c382-43e9-af82-0507f2c63901} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): (while reading column id): (while reading from part /var/lib/clickhouse/store/ff2/ff20fbf9-207c-493f-a77a-d5581e94b56c/all_0_0_0/ in table test_1.test_table (ff20fbf9-207c-493f-a77a-d5581e94b56c) located on disk default of type local, from mark 0 with max_rows_to_read = 3): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:38648) (comment: 03231_pr_duplicate_announcement.sql) (in query: SELECT id, value FROM test_table WHERE id IN (SELECT id FROM test_table_for_in UNION DISTINCT SELECT id FROM test_table_for_in);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d62f83 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d65385 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d655fe 16. DB::ReadBuffer::next() @ 0x0000000007b3717b 17. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:85: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000001702b2e9 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bcd448 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bee90e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5b63 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a967e6a 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 28. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 29. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 2025.10.23 23:54:40.642767 [ 10936 ] {bc28c6ea-c382-43e9-af82-0507f2c63901} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): (while reading column id): (while reading from part /var/lib/clickhouse/store/ff2/ff20fbf9-207c-493f-a77a-d5581e94b56c/all_0_0_0/ in table test_1.test_table (ff20fbf9-207c-493f-a77a-d5581e94b56c) located on disk default of type local, from mark 0 with max_rows_to_read = 3): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d62f83 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d65385 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d655fe 16. DB::ReadBuffer::next() @ 0x0000000007b3717b 17. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:85: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000001702b2e9 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bcd448 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bee90e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5b63 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a967e6a 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 28. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 29. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 2025.10.23 23:54:40.851562 [ 4100 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:47018, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe5aed 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fbe4c7d 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fbe52f4 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:0: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a06adcf 6. DB::ReadBuffer::next() @ 0x0000000007b3717b 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001a1eb31a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:40.852171 [ 3875 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:47570, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe5aed 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fbe4c7d 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fbe52f4 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:0: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a06adcf 6. DB::ReadBuffer::next() @ 0x0000000007b3717b 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001a1eb31a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:42.540282 [ 4108 ] {mysql:4:06839d38-36cf-46b6-ac89-9cd051d5479b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:40844) (in query: SELECT `key` FROM `test_1`.`foo`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2f303a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000182258bc 12. ./build_docker/./src/Server/MySQLHandler.cpp:519: DB::MySQLHandler::comQuery(DB::ReadBuffer&, bool) @ 0x000000001a186feb 13. ./build_docker/./src/Server/MySQLHandler.cpp:289: DB::MySQLHandler::run() @ 0x000000001a182461 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:54:42.544422 [ 4108 ] {} MySQLHandler: MySQLHandler: Cannot read packet: : Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2f303a 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000182258bc 12. ./build_docker/./src/Server/MySQLHandler.cpp:519: DB::MySQLHandler::comQuery(DB::ReadBuffer&, bool) @ 0x000000001a186feb 13. ./build_docker/./src/Server/MySQLHandler.cpp:289: DB::MySQLHandler::run() @ 0x000000001a182461 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:42.546190 [ 4392 ] {3c77c41a-041f-41c6-a583-6826270a4029} MySQLSource: Error processing query 'SELECT `key` FROM `test_1`.`foo`': mysqlxx::BadQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) while executing query: 'SELECT `key` FROM `test_1`.`foo`' (127.0.0.1:9004) 2025.10.23 23:54:42.696885 [ 10936 ] {3c77c41a-041f-41c6-a583-6826270a4029} executeQuery: Poco::Exception. Code: 1000, e.code() = 439, mysqlxx::BadQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) while executing query: 'SELECT `key` FROM `test_1`.`foo`' (127.0.0.1:9004) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:38734) (comment: 02479_mysql_connect_to_self.sql) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', currentDatabase(), foo, 'default', '[HIDDEN]', SETTINGS connect_timeout = 100, connection_wait_timeout = 100)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./src/Common/mysqlxx/./mysqlxx/Exception.h:41: mysqlxx::Query::executeImpl() @ 0x000000001e55d239 2. ./build_docker/./src/Common/mysqlxx/Query.cpp:74: mysqlxx::Query::use() @ 0x000000001e55d621 3. ./build_docker/./src/Processors/Sources/MySQLSource.cpp:54: DB::MySQLSource::Connection::Connection(mysqlxx::Pool::Entry const&, String const&) @ 0x000000001a7bf8b4 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::MySQLWithFailoverSource::onStart() @ 0x000000001a7c0dda 5. ./build_docker/./src/Processors/Sources/MySQLSource.cpp:129: DB::MySQLWithFailoverSource::generate() @ 0x000000001a7c1eba 6. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2e13d5 7. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:54:42.697607 [ 10936 ] {3c77c41a-041f-41c6-a583-6826270a4029} TCPHandler: Code: 1000. DB::Exception: mysqlxx::BadQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) while executing query: 'SELECT `key` FROM `test_1`.`foo`' (127.0.0.1:9004). (POCO_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./src/Common/mysqlxx/./mysqlxx/Exception.h:41: mysqlxx::Query::executeImpl() @ 0x000000001e55d239 2. ./build_docker/./src/Common/mysqlxx/Query.cpp:74: mysqlxx::Query::use() @ 0x000000001e55d621 3. ./build_docker/./src/Processors/Sources/MySQLSource.cpp:54: DB::MySQLSource::Connection::Connection(mysqlxx::Pool::Entry const&, String const&) @ 0x000000001a7bf8b4 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::MySQLWithFailoverSource::onStart() @ 0x000000001a7c0dda 5. ./build_docker/./src/Processors/Sources/MySQLSource.cpp:129: DB::MySQLWithFailoverSource::generate() @ 0x000000001a7c1eba 6. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2e13d5 7. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 12. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:54:45.600066 [ 10385 ] {c3d322a1-c6f7-4339-af1b-7bb0917ee26d} executeQuery: Code: 48. DB::Exception: CHECK PART/PARTITION are not supported for TinyLog. (NOT_IMPLEMENTED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:38856) (comment: 00063_check_query.sql) (in query: CHECK TABLE check_query_tiny_log PARTITION tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Storages/StorageLog.cpp:0: DB::StorageLog::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x00000000195c8a48 5. ./build_docker/./src/Interpreters/InterpreterCheckQuery.cpp:103: DB::InterpreterCheckQuery::execute() @ 0x000000001829be78 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:54:45.601535 [ 10385 ] {c3d322a1-c6f7-4339-af1b-7bb0917ee26d} TCPHandler: Code: 48. DB::Exception: CHECK PART/PARTITION are not supported for TinyLog. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Storages/StorageLog.cpp:0: DB::StorageLog::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x00000000195c8a48 5. ./build_docker/./src/Interpreters/InterpreterCheckQuery.cpp:103: DB::InterpreterCheckQuery::execute() @ 0x000000001829be78 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:54:45.609415 [ 10385 ] {7516fea9-e045-4110-9eff-db511f18d4c3} executeQuery: Code: 48. DB::Exception: CHECK PART/PARTITION are not supported for TinyLog. (NOT_IMPLEMENTED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:38856) (comment: 00063_check_query.sql) (in query: CHECK TABLE check_query_tiny_log PART 'all_0_0_0';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Storages/StorageLog.cpp:0: DB::StorageLog::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x00000000195c8a48 5. ./build_docker/./src/Interpreters/InterpreterCheckQuery.cpp:103: DB::InterpreterCheckQuery::execute() @ 0x000000001829be78 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:54:45.610049 [ 10385 ] {7516fea9-e045-4110-9eff-db511f18d4c3} TCPHandler: Code: 48. DB::Exception: CHECK PART/PARTITION are not supported for TinyLog. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Storages/StorageLog.cpp:0: DB::StorageLog::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x00000000195c8a48 5. ./build_docker/./src/Interpreters/InterpreterCheckQuery.cpp:103: DB::InterpreterCheckQuery::execute() @ 0x000000001829be78 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:54:45.625746 [ 10385 ] {8e0523aa-45d9-48bd-b036-a817fe93face} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:38856) (comment: 00063_check_query.sql) (in query: -- Settings and FORMAT are supported CHECK TABLE check_query_tiny_log SETTINGS max_threads = 16;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f5511 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:54:45.628156 [ 10385 ] {8e0523aa-45d9-48bd-b036-a817fe93face} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f5511 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:54:46.045044 [ 2725 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:48.040260 [ 3320 ] {40faa80e-86c4-4769-8e34-1aa660c156dc::202510_17_17_0_20} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:48.041167 [ 3320 ] {40faa80e-86c4-4769-8e34-1aa660c156dc::202510_17_17_0_20} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:48.041472 [ 3309 ] {40faa80e-86c4-4769-8e34-1aa660c156dc::202510_19_19_0_20} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:48.042664 [ 10385 ] {dc8436bb-e97e-412f-9001-fed772487067} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_20.txt' with part '202510_17_17_0' reason: 'Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:38902) (comment: 02833_concurrent_sessions.sh) (in query: DELETE FROM system.session_log WHERE user IN ('02833_TCP_USER_10991_1','02833_TCP_USER_10991_2','02833_HTTP_USER_10991','02833_HTTP_WITH_SESSION_ID_USER_10991','02833_MYSQL_USER_10991')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000019ba6454 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000019ba635c 5. ./src/Common/SharedLockGuard.h:19: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000019e594c0 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000019e5a922 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c29b97 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 9. ./src/Interpreters/InterpreterAlterQuery.h:18: DB::InterpreterDeleteQuery::execute()::$_0::operator()() const @ 0x00000000182c7a44 10. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:0: DB::InterpreterDeleteQuery::execute() @ 0x00000000182c5b53 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.23 23:54:48.043349 [ 3309 ] {40faa80e-86c4-4769-8e34-1aa660c156dc::202510_19_19_0_20} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:48.045413 [ 10385 ] {dc8436bb-e97e-412f-9001-fed772487067} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_20.txt' with part '202510_17_17_0' reason: 'Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000019ba6454 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:0: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000019ba635c 5. ./src/Common/SharedLockGuard.h:19: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000019e594c0 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x0000000019e5a922 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c29b97 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 9. ./src/Interpreters/InterpreterAlterQuery.h:18: DB::InterpreterDeleteQuery::execute()::$_0::operator()() const @ 0x00000000182c7a44 10. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:0: DB::InterpreterDeleteQuery::execute() @ 0x00000000182c5b53 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.23 23:54:48.561046 [ 4099 ] {5e11cae2-f018-46ec-94d2-981434e140c6} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.018783'): 0.018783. Expected one of: token sequence, Dot, token, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, QUALIFY, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR) (version 24.8.14.10544.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:40648) (comment: 02833_concurrent_sessions.sh) (in query: SELECT 5, sleep 0.018783), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000764baa3 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001b028e50 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001b028f0f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821d0ab 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 8. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:54:48.562445 [ 4099 ] {5e11cae2-f018-46ec-94d2-981434e140c6} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.018783'): 0.018783. Expected one of: token sequence, Dot, token, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, QUALIFY, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000764baa3 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001b028e50 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001b028f0f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821d0ab 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 8. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:48.736967 [ 10385 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_USER_10991: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000166be635 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000017f14ce3 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:0: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000001a228e4f 6. ./build_docker/./src/Server/HTTPHandler.cpp:202: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001a13db06 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:48.737009 [ 3875 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_WITH_SESSION_ID_USER_10991: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000166be635 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000017f14ce3 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:0: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000001a228e4f 6. ./build_docker/./src/Server/HTTPHandler.cpp:202: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001a13db06 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:48.756483 [ 2687 ] {42134ac9-9bd8-4c33-ac82-aa2cb97dec15} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.0113249'): 0.0113249. Expected one of: token sequence, Dot, token, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, QUALIFY, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR) (version 24.8.14.10544.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:40696) (comment: 02833_concurrent_sessions.sh) (in query: SELECT 5, sleep 0.0113249), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000764baa3 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001b028e50 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001b028f0f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821d0ab 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 8. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:54:48.757567 [ 2687 ] {42134ac9-9bd8-4c33-ac82-aa2cb97dec15} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.0113249'): 0.0113249. Expected one of: token sequence, Dot, token, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, QUALIFY, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000764baa3 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001b028e50 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001b028f0f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821d0ab 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 8. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:48.767618 [ 2687 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_WITH_SESSION_ID_USER_10991: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000166be635 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000017f14ce3 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:0: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000001a228e4f 6. ./build_docker/./src/Server/HTTPHandler.cpp:202: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001a13db06 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:48.791050 [ 10385 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_USER_10991: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000166be635 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000017f14ce3 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:0: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000001a228e4f 6. ./build_docker/./src/Server/HTTPHandler.cpp:202: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001a13db06 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:48.838223 [ 2687 ] {101a2e7f-a983-4620-8d65-02a12a3cca59} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.0118794'): 0.0118794. Expected one of: token sequence, Dot, token, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, QUALIFY, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR) (version 24.8.14.10544.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:40706) (comment: 02833_concurrent_sessions.sh) (in query: SELECT 5, sleep 0.0118794), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000764baa3 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001b028e50 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001b028f0f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821d0ab 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 8. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:54:48.839885 [ 2687 ] {101a2e7f-a983-4620-8d65-02a12a3cca59} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 17 ('0.0118794'): 0.0118794. Expected one of: token sequence, Dot, token, OR, AND, IS NOT DISTINCT FROM, IS NULL, IS NOT NULL, BETWEEN, NOT BETWEEN, LIKE, ILIKE, NOT LIKE, NOT ILIKE, REGEXP, IN, NOT IN, GLOBAL IN, GLOBAL NOT IN, MOD, DIV, alias, AS, identifier, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, QUALIFY, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000764baa3 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000001b028e50 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000001b028f0f 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821d0ab 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 8. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:48.855415 [ 10385 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_WITH_SESSION_ID_USER_10991: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000166be635 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000017f14ce3 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:0: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000001a228e4f 6. ./build_docker/./src/Server/HTTPHandler.cpp:202: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001a13db06 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:48.925374 [ 2687 ] {} DynamicQueryHandler: Code: 516. DB::Exception: 02833_HTTP_USER_10991: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000166be635 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000017f14ce3 5. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:0: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000001a228e4f 6. ./build_docker/./src/Server/HTTPHandler.cpp:202: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001a13db06 7. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:49.702215 [ 10385 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_10991_1: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000166be635 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000017f14ce3 5. ./src/Access/Credentials.h:54: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000017f1456a 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x000000001a1f475d 7. ./build_docker/./src/Server/TCPHandler.cpp:282: DB::TCPHandler::runImpl() @ 0x000000001a1ea990 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:49.702700 [ 3875 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_10991_2: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000166be635 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000017f14ce3 5. ./src/Access/Credentials.h:54: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000017f1456a 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x000000001a1f475d 7. ./build_docker/./src/Server/TCPHandler.cpp:282: DB::TCPHandler::runImpl() @ 0x000000001a1ea990 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:50.079869 [ 4108 ] {} MySQLHandler: Authentication for user 02833_MYSQL_USER_10991 failed. 2025.10.23 23:54:50.080193 [ 4108 ] {} MySQLHandler: DB::Exception: 02833_MYSQL_USER_10991: Authentication failed: password is incorrect, or there is no user with such name. 2025.10.23 23:54:50.081429 [ 4100 ] {bc1f399e-df9d-4b57-a54b-ddf417fe80d6} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user 02833_MYSQL_USER_10991): mysqlxx::ConnectionFailed 2025.10.23 23:54:50.082103 [ 4100 ] {bc1f399e-df9d-4b57-a54b-ddf417fe80d6} Application: Connection to system@127.0.0.1:9004 as user 02833_MYSQL_USER_10991 failed: mysqlxx::ConnectionFailed: 02833_MYSQL_USER_10991: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.10.23 23:54:50.082375 [ 4100 ] {bc1f399e-df9d-4b57-a54b-ddf417fe80d6} Application: Connection to mysql failed 1 times 2025.10.23 23:54:50.413734 [ 4100 ] {bc1f399e-df9d-4b57-a54b-ddf417fe80d6} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_10991, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_10991: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59864) (comment: 02833_concurrent_sessions.sh) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', '02833_MYSQL_USER_10991', '[HIDDEN]', SETTINGS connection_max_tries = 1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x000000001e576213 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:0: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001724a877 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000019319bea 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x0000000019319484 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000015eaedea 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015eae0a8 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 11. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.23 23:54:50.415265 [ 4100 ] {bc1f399e-df9d-4b57-a54b-ddf417fe80d6} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_10991, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_10991: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x000000001e576213 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:0: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001724a877 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000019319bea 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x0000000019319484 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000015eaedea 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015eae0a8 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 11. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.23 23:54:50.652639 [ 3875 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_10991_2: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000166be635 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000017f14ce3 5. ./src/Access/Credentials.h:54: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000017f1456a 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x000000001a1f475d 7. ./build_docker/./src/Server/TCPHandler.cpp:282: DB::TCPHandler::runImpl() @ 0x000000001a1ea990 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:50.685343 [ 3875 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_10991_1: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000166be635 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000017f14ce3 5. ./src/Access/Credentials.h:54: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000017f1456a 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x000000001a1f475d 7. ./build_docker/./src/Server/TCPHandler.cpp:282: DB::TCPHandler::runImpl() @ 0x000000001a1ea990 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:51.614220 [ 3875 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_10991_2: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000166be635 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000017f14ce3 5. ./src/Access/Credentials.h:54: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000017f1456a 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x000000001a1f475d 7. ./build_docker/./src/Server/TCPHandler.cpp:282: DB::TCPHandler::runImpl() @ 0x000000001a1ea990 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:51.673375 [ 3875 ] {} ServerErrorHandler: Code: 516. DB::Exception: 02833_TCP_USER_10991_1: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./build_docker/./src/Access/AccessControl.cpp:0: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x00000000166be635 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000017f14ce3 5. ./src/Access/Credentials.h:54: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000017f1456a 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receiveHello() @ 0x000000001a1f475d 7. ./build_docker/./src/Server/TCPHandler.cpp:282: DB::TCPHandler::runImpl() @ 0x000000001a1ea990 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:54:51.860065 [ 4108 ] {} MySQLHandler: Authentication for user 02833_MYSQL_USER_10991 failed. 2025.10.23 23:54:51.860356 [ 4108 ] {} MySQLHandler: DB::Exception: 02833_MYSQL_USER_10991: Authentication failed: password is incorrect, or there is no user with such name. 2025.10.23 23:54:51.861076 [ 3875 ] {8b666fa3-047f-434c-abdc-a4ad7ca92efe} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user 02833_MYSQL_USER_10991): mysqlxx::ConnectionFailed 2025.10.23 23:54:51.861604 [ 3875 ] {8b666fa3-047f-434c-abdc-a4ad7ca92efe} Application: Connection to system@127.0.0.1:9004 as user 02833_MYSQL_USER_10991 failed: mysqlxx::ConnectionFailed: 02833_MYSQL_USER_10991: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.10.23 23:54:51.861796 [ 3875 ] {8b666fa3-047f-434c-abdc-a4ad7ca92efe} Application: Connection to mysql failed 1 times 2025.10.23 23:54:51.864083 [ 3875 ] {8b666fa3-047f-434c-abdc-a4ad7ca92efe} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_10991, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_10991: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59950) (comment: 02833_concurrent_sessions.sh) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', '02833_MYSQL_USER_10991', '[HIDDEN]', SETTINGS connection_max_tries = 1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x000000001e576213 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:0: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001724a877 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000019319bea 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x0000000019319484 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000015eaedea 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015eae0a8 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 11. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.23 23:54:51.866081 [ 3875 ] {8b666fa3-047f-434c-abdc-a4ad7ca92efe} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_10991, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_10991: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x000000001e576213 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:0: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001724a877 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000019319bea 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x0000000019319484 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000015eaedea 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015eae0a8 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 11. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.23 23:54:53.452004 [ 4108 ] {} MySQLHandler: Authentication for user 02833_MYSQL_USER_10991 failed. 2025.10.23 23:54:53.452297 [ 4108 ] {} MySQLHandler: DB::Exception: 02833_MYSQL_USER_10991: Authentication failed: password is incorrect, or there is no user with such name. 2025.10.23 23:54:53.453074 [ 3875 ] {5bd1b268-caa6-4f7d-92f5-d462d4309973} mysqlxx::Pool: Failed to connect to MySQL (system@127.0.0.1:9004 as user 02833_MYSQL_USER_10991): mysqlxx::ConnectionFailed 2025.10.23 23:54:53.453615 [ 3875 ] {5bd1b268-caa6-4f7d-92f5-d462d4309973} Application: Connection to system@127.0.0.1:9004 as user 02833_MYSQL_USER_10991 failed: mysqlxx::ConnectionFailed: 02833_MYSQL_USER_10991: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004) 2025.10.23 23:54:53.453918 [ 3875 ] {5bd1b268-caa6-4f7d-92f5-d462d4309973} Application: Connection to mysql failed 1 times 2025.10.23 23:54:53.456530 [ 3875 ] {5bd1b268-caa6-4f7d-92f5-d462d4309973} executeQuery: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_10991, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_10991: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:60002) (comment: 02833_concurrent_sessions.sh) (in query: SELECT 1 FROM mysql('127.0.0.1:9004', 'system', 'one', '02833_MYSQL_USER_10991', '[HIDDEN]', SETTINGS connection_max_tries = 1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x000000001e576213 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:0: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001724a877 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000019319bea 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x0000000019319484 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000015eaedea 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015eae0a8 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 11. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.23 23:54:53.458644 [ 3875 ] {5bd1b268-caa6-4f7d-92f5-d462d4309973} TCPHandler: Code: 279. DB::Exception: Connections to mysql failed: system@127.0.0.1:9004 as user 02833_MYSQL_USER_10991, ERROR 516 : mysqlxx::ConnectionFailed: 02833_MYSQL_USER_10991: Authentication failed: password is incorrect, or there is no user with such name. ((nullptr):9004). (ALL_CONNECTION_TRIES_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Common/mysqlxx/PoolWithFailover.cpp:0: mysqlxx::PoolWithFailover::get() @ 0x000000001e576213 5. ./build_docker/./src/Databases/MySQL/FetchTablesColumnsList.cpp:0: DB::fetchTablesColumnsList(mysqlxx::PoolWithFailover&, String const&, std::vector> const&, DB::Settings const&, MultiEnum) @ 0x000000001724a877 6. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::getTableStructureFromData(mysqlxx::PoolWithFailover&, String const&, String const&, std::shared_ptr const&) @ 0x0000000019319bea 7. ./build_docker/./src/Storages/StorageMySQL.cpp:0: DB::StorageMySQL::StorageMySQL(DB::StorageID const&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool, String const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, DB::MySQLSettings const&) @ 0x0000000019319484 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, mysqlxx::PoolWithFailover, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::shared_ptr&, DB::MySQLSettings, void>(std::allocator const&, DB::StorageID&&, mysqlxx::PoolWithFailover&&, String const&, String const&, bool const&, String const&, DB::ColumnsDescription&, DB::ConstraintsDescription&&, String&&, std::shared_ptr&, DB::MySQLSettings&&) @ 0x0000000015eaedea 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::(anonymous namespace)::TableFunctionMySQL::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015eae0a8 10. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 11. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.23 23:54:53.662463 [ 3316 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {40faa80e-86c4-4769-8e34-1aa660c156dc::202510_1_22_4_20}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:55:01.679105 [ 3315 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4e167706-dfb8-4318-8e40-8928b14b09ce::202510_1_86_17}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:55:02.454080 [ 3875 ] {728e724c-3df3-4a88-8141-408cd106889f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47064) (comment: 02833_concurrent_sessions.sh) (in query: SELECT count(*) FROM system.session_log WHERE user IN ('02833_TCP_USER_10991_1','02833_TCP_USER_10991_2') AND interface = 'TCP'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c143b7 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9bdbb2 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a967e00 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 28. __tsan_thread_start_func @ 0x000000000758df2f 29. ? @ 0x00007f7c69445ac3 30. ? @ 0x00007f7c694d7850 2025.10.23 23:55:02.460356 [ 3875 ] {728e724c-3df3-4a88-8141-408cd106889f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c143b7 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9bdbb2 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a967e00 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 28. __tsan_thread_start_func @ 0x000000000758df2f 29. ? @ 0x00007f7c69445ac3 30. ? @ 0x00007f7c694d7850 2025.10.23 23:55:02.546420 [ 10929 ] {0a4ac9e5-a997-4ac7-8778-fd401ad0f4e3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47058) (comment: 02011_normalize_utf8.sql) (in query: SELECT id, value, length(value), normalizeUTF8NFC(value) AS nfc, length(nfc) AS nfc_len, normalizeUTF8NFD(value) AS nfd, length(nfd) AS nfd_len, normalizeUTF8NFKC(value) AS nfkc, length(nfkc) AS nfkc_len, normalizeUTF8NFKD(value) AS nfkd, length(nfkd) AS nfkd_len FROM normalize_test ORDER BY id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9878c6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9bdbb2 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a967e00 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 28. __tsan_thread_start_func @ 0x000000000758df2f 29. ? @ 0x00007f7c69445ac3 30. ? @ 0x00007f7c694d7850 2025.10.23 23:55:02.548551 [ 10929 ] {0a4ac9e5-a997-4ac7-8778-fd401ad0f4e3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a9878c6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9bdbb2 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a967e00 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 28. __tsan_thread_start_func @ 0x000000000758df2f 29. ? @ 0x00007f7c69445ac3 30. ? @ 0x00007f7c694d7850 2025.10.23 23:55:02.815067 [ 3312 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4e167706-dfb8-4318-8e40-8928b14b09ce::202510_1_86_17}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:55:02.832343 [ 3315 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4e167706-dfb8-4318-8e40-8928b14b09ce::202510_1_86_17}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:55:03.087370 [ 3875 ] {9119cdbb-554a-4ed3-b37c-d3373bc0cc38} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47090) (comment: 02833_concurrent_sessions.sh) (in query: SELECT count(*) FROM system.session_log WHERE user IN ('02833_HTTP_USER_10991') AND interface = 'HTTP'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:55:03.091697 [ 3875 ] {9119cdbb-554a-4ed3-b37c-d3373bc0cc38} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:55:03.191126 [ 10930 ] {7926c09a-5bd0-4fb3-9b62-f2ca296dd8f7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=724). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47100) (comment: 00688_low_cardinality_dictionary_deserialization.sql) (in query: insert into lc_dict_reading select number, if(number < 8192 * 4, number % 100, number) as s, s from system.numbers limit 1000000;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f2d53 8. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000001a1ec1ec 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:55:03.192396 [ 10930 ] {7926c09a-5bd0-4fb3-9b62-f2ca296dd8f7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=724). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f2d53 8. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000001a1ec1ec 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:55:05.428327 [ 3875 ] {45d412e7-b997-4265-9b44-b99fe9521389} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT divideDecimal(toDecimal64(123.123, 3), toDecimal64(0, 1)). (ILLEGAL_DIVISION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47148) (comment: 02475_precise_decimal_arithmetics.sql) (in query: SELECT divideDecimal(toDecimal64(123.123, 3), toDecimal64(0, 1));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. DB::Decimal> DB::(anonymous namespace)::DivideDecimalsImpl::execute, DB::Decimal>(DB::Decimal, DB::Decimal, unsigned short, unsigned short, unsigned short) @ 0x00000000099877f0 5. void DB::Processor>>, DB::(anonymous namespace)::DivideDecimalsImpl>::vectorVector, 4096ul, Allocator, 63ul, 64ul>, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>&, unsigned short, unsigned short, unsigned short, unsigned long) const @ 0x0000000009987040 6. DB::FunctionsDecimalArithmetics::resolveOverload(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000997fe23 7. DB::FunctionsDecimalArithmetics::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000997d4b1 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 2025.10.23 23:55:05.429028 [ 3875 ] {45d412e7-b997-4265-9b44-b99fe9521389} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT divideDecimal(toDecimal64(123.123, 3), toDecimal64(0, 1)). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. DB::Decimal> DB::(anonymous namespace)::DivideDecimalsImpl::execute, DB::Decimal>(DB::Decimal, DB::Decimal, unsigned short, unsigned short, unsigned short) @ 0x00000000099877f0 5. void DB::Processor>>, DB::(anonymous namespace)::DivideDecimalsImpl>::vectorVector, 4096ul, Allocator, 63ul, 64ul>, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray>, 4096ul, Allocator, 63ul, 64ul>&, unsigned short, unsigned short, unsigned short, unsigned long) const @ 0x0000000009987040 6. DB::FunctionsDecimalArithmetics::resolveOverload(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000997fe23 7. DB::FunctionsDecimalArithmetics::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000997d4b1 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 2025.10.23 23:55:05.502624 [ 3875 ] {dc0cdbdb-6068-4c70-9bcc-28341d7f2982} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=724). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47148) (comment: 02475_precise_decimal_arithmetics.sql) (in query: -- don't look at strange query result -- it happens due to bad float precision: toUInt256(1e38) == 99999999999999997752612184630461283328 SELECT multiplyDecimal(toDecimal256(1e38, 0), toDecimal256(1e38, 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:55:05.503228 [ 3875 ] {dc0cdbdb-6068-4c70-9bcc-28341d7f2982} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=724). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:55:06.436275 [ 10930 ] {55bdc353-fca9-43ac-a924-dda7490a125c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47224) (comment: 02833_concurrent_sessions.sh) (in query: SELECT COUNT(*) FROM system.session_log WHERE user = '02833_TCP_USER_10991_1' AND type = 'LoginFailure'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:55:06.438721 [ 10930 ] {55bdc353-fca9-43ac-a924-dda7490a125c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:55:06.957741 [ 3875 ] {63c92ab6-ec96-4920-9e68-ce9fb6025be4} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47246) (comment: 01825_type_json_2.sql) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:55:07.046294 [ 3875 ] {63c92ab6-ec96-4920-9e68-ce9fb6025be4} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:55:07.827964 [ 10931 ] {2ff437ff-7c7c-44e1-a1c7-24163cfb9499} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47280) (comment: 00665_alter_nullable_string_to_nullable_uint8.sql) (in query: SELECT * FROM alter_00665 ORDER BY boolean_false NULLS LAST;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c63e3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.23 23:55:07.829583 [ 10931 ] {2ff437ff-7c7c-44e1-a1c7-24163cfb9499} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c63e3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 24. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.23 23:55:10.364914 [ 10930 ] {34b95a09-e6a1-4288-bd09-3f5e668c13a6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56034) (comment: 02833_concurrent_sessions.sh) (in query: SELECT COUNT(*) FROM system.session_log WHERE user = '02833_HTTP_USER_10991' AND type = 'LoginFailure'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019afcfca 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001a947c35 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a94638f 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1454: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a946030 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001aa2d4c7 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001aa049ce 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001a92223a 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a920d30 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dc3569 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017dc3210 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 2025.10.23 23:55:10.366011 [ 10930 ] {34b95a09-e6a1-4288-bd09-3f5e668c13a6} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019afcfca 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001a947c35 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a94638f 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1454: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a946030 11. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000001aa2d4c7 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001aa049ce 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001a92223a 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a920d30 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dc3569 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017dc3210 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 2025.10.23 23:55:11.241280 [ 2921 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:55:13.456771 [ 10930 ] {2c7b123b-ef01-49a0-9685-a9768d9d6b43} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56136) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000007649e6c 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007647bf1 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b86b6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.23 23:55:13.457657 [ 10930 ] {2c7b123b-ef01-49a0-9685-a9768d9d6b43} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000007649e6c 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007647bf1 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b86b6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.23 23:55:14.004004 [ 10930 ] {9224236f-c196-4ec3-b13a-98612f837bcd} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: Date: In scope SELECT YYYYMMDDhhmmssToDateTime(toDate('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56136) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime(toDate('2023-09-11'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b86b6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:14.006999 [ 10930 ] {9224236f-c196-4ec3-b13a-98612f837bcd} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: Date: In scope SELECT YYYYMMDDhhmmssToDateTime(toDate('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b86b6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:14.022240 [ 10930 ] {0c5cc182-6921-4ba0-b8f8-80857ecb1cfd} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: Date32: In scope SELECT YYYYMMDDhhmmssToDateTime(toDate32('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56136) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime(toDate32('2023-09-11'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b86b6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:14.024195 [ 10930 ] {0c5cc182-6921-4ba0-b8f8-80857ecb1cfd} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: Date32: In scope SELECT YYYYMMDDhhmmssToDateTime(toDate32('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b86b6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:14.069446 [ 10930 ] {96a39911-6de3-4557-a1d0-4ad30b883c7d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: DateTime: In scope SELECT YYYYMMDDhhmmssToDateTime(toDateTime('2023-09-11 12:18:00')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56136) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime(toDateTime('2023-09-11 12:18:00'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b86b6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:14.070478 [ 10930 ] {96a39911-6de3-4557-a1d0-4ad30b883c7d} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: DateTime: In scope SELECT YYYYMMDDhhmmssToDateTime(toDateTime('2023-09-11 12:18:00')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b86b6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:14.084039 [ 10930 ] {d62466be-0bdd-4c1a-8a85-d7252c2f286c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: DateTime64(3): In scope SELECT YYYYMMDDhhmmssToDateTime(toDateTime64('2023-09-11 12:18:00', 3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56136) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime(toDateTime64('2023-09-11 12:18:00', 3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b86b6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:14.085109 [ 10930 ] {d62466be-0bdd-4c1a-8a85-d7252c2f286c} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: DateTime64(3): In scope SELECT YYYYMMDDhhmmssToDateTime(toDateTime64('2023-09-11 12:18:00', 3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b86b6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:14.095109 [ 10930 ] {cf9cb7df-80e4-47da-9c89-0a53bcf9a934} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: String: In scope SELECT YYYYMMDDhhmmssToDateTime('2023-09-11'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56136) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime('2023-09-11');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b86b6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:14.095951 [ 10930 ] {cf9cb7df-80e4-47da-9c89-0a53bcf9a934} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: String: In scope SELECT YYYYMMDDhhmmssToDateTime('2023-09-11'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b86b6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:15.026166 [ 10930 ] {4543350d-c1bf-41c9-9d28-010653964a0c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'YYYYMMDDhhmmssToDateTime'. Expected: const String, got: UInt8: In scope SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56136) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764787a 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b86b6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:15.028046 [ 10930 ] {4543350d-c1bf-41c9-9d28-010653964a0c} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'YYYYMMDDhhmmssToDateTime'. Expected: const String, got: UInt8: In scope SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764787a 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b86b6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:15.321348 [ 10930 ] {1932afc3-be60-4c2c-8a2f-15d2aa82a1ea} executeQuery: Code: 36. DB::Exception: Cannot load time zone invalid tz: In scope SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 'invalid tz'). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56136) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 'invalid tz');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000000f9ee668 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x000000000f9e9047 6. ./src/Common/DateLUT.h:0: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000016e45ab5 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:12: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x0000000016e455fe 8. std::shared_ptr std::allocate_shared[abi:v15007], String&, void>(std::allocator const&, String&) @ 0x000000000944e382 9. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b8722 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 2025.10.23 23:55:15.324358 [ 10930 ] {1932afc3-be60-4c2c-8a2f-15d2aa82a1ea} TCPHandler: Code: 36. DB::Exception: Cannot load time zone invalid tz: In scope SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 'invalid tz'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000000f9ee668 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x000000000f9e9047 6. ./src/Common/DateLUT.h:0: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000016e45ab5 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:12: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x0000000016e455fe 8. std::shared_ptr std::allocate_shared[abi:v15007], String&, void>(std::allocator const&, String&) @ 0x000000000944e382 9. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b8722 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 2025.10.23 23:55:15.411272 [ 10930 ] {e70a3370-0325-40b2-9f0a-cf858491a731} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 'Europe/Berlin', 'bad'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56136) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 'Europe/Berlin', 'bad');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000007649e6c 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007647bf1 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b86b6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.23 23:55:15.413119 [ 10930 ] {e70a3370-0325-40b2-9f0a-cf858491a731} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 'Europe/Berlin', 'bad'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000007649e6c 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007647bf1 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b86b6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.23 23:55:16.397664 [ 10930 ] {dfe5f44d-0607-4310-85be-03539faf368a} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime(nan). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56136) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime(NaN);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c0b83f5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.23 23:55:16.398940 [ 10930 ] {dfe5f44d-0607-4310-85be-03539faf368a} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime(nan). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c0b83f5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.23 23:55:16.412663 [ 10930 ] {16708c63-7ffe-4bc9-854d-3e46207af5ca} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime(inf). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56136) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime(Inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c0b83f5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.23 23:55:16.413789 [ 10930 ] {16708c63-7ffe-4bc9-854d-3e46207af5ca} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime(inf). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c0b83f5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.23 23:55:16.443649 [ 10930 ] {370814f9-51db-42c8-b7e2-6a6ad565b97d} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime(-inf). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56136) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime(-Inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c0b83f5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.23 23:55:16.444653 [ 10930 ] {370814f9-51db-42c8-b7e2-6a6ad565b97d} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime(-inf). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c0b83f5 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.23 23:55:16.666241 [ 10931 ] {9db4eb5d-0d62-42fc-8918-b6d4eaf42cf6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56216) (comment: 02320_alter_columns_with_dots.sql) (in query: DESC TABLE test;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:55:16.752566 [ 10931 ] {9db4eb5d-0d62-42fc-8918-b6d4eaf42cf6} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=725). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:55:17.401973 [ 10930 ] {950c3d0f-0ae3-4529-870a-a039766a2761} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56136) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000007649e6c 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007647bf1 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b96d6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.23 23:55:17.403396 [ 10930 ] {950c3d0f-0ae3-4529-870a-a039766a2761} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000007649e6c 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007647bf1 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b96d6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.23 23:55:17.691906 [ 10930 ] {734940c2-eba4-4559-8f2c-91bfeb7d5817} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: Date: In scope SELECT YYYYMMDDhhmmssToDateTime64(toDate('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56136) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64(toDate('2023-09-11'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b96d6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:17.692641 [ 10930 ] {734940c2-eba4-4559-8f2c-91bfeb7d5817} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: Date: In scope SELECT YYYYMMDDhhmmssToDateTime64(toDate('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b96d6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:17.701308 [ 10930 ] {e49d75d2-1953-4808-9bd2-fcb33cb0bb10} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: Date32: In scope SELECT YYYYMMDDhhmmssToDateTime64(toDate32('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56136) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64(toDate32('2023-09-11'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b96d6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:17.701851 [ 10930 ] {e49d75d2-1953-4808-9bd2-fcb33cb0bb10} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: Date32: In scope SELECT YYYYMMDDhhmmssToDateTime64(toDate32('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b96d6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:17.711208 [ 10930 ] {726a7013-fcbb-4c21-912d-d9d5c6b90618} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: DateTime: In scope SELECT YYYYMMDDhhmmssToDateTime64(toDateTime('2023-09-11 12:18:00')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56136) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64(toDateTime('2023-09-11 12:18:00'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b96d6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:17.711795 [ 10930 ] {726a7013-fcbb-4c21-912d-d9d5c6b90618} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: DateTime: In scope SELECT YYYYMMDDhhmmssToDateTime64(toDateTime('2023-09-11 12:18:00')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b96d6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:17.720606 [ 10930 ] {5073b216-99f0-4f88-b3ce-a2d0e8c2ee42} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: DateTime64(3): In scope SELECT YYYYMMDDhhmmssToDateTime64(toDateTime64('2023-09-11 12:18:00', 3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56136) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64(toDateTime64('2023-09-11 12:18:00', 3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b96d6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:17.721150 [ 10930 ] {5073b216-99f0-4f88-b3ce-a2d0e8c2ee42} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: DateTime64(3): In scope SELECT YYYYMMDDhhmmssToDateTime64(toDateTime64('2023-09-11 12:18:00', 3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b96d6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:17.728873 [ 10930 ] {5c801605-1996-4ac4-bd9a-beee212ac11a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: String: In scope SELECT YYYYMMDDhhmmssToDateTime64('2023-09-11'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56136) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64('2023-09-11');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b96d6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:17.729366 [ 10930 ] {5c801605-1996-4ac4-bd9a-beee212ac11a} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: String: In scope SELECT YYYYMMDDhhmmssToDateTime64('2023-09-11'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b96d6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:17.736780 [ 10930 ] {beffa840-3598-4df5-b626-15613dbd2af8} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: String: In scope SELECT YYYYMMDDhhmmssToDateTime64('2023-09-11', 'invalid precision'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56136) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64('2023-09-11', 'invalid precision');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b96d6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:17.737260 [ 10930 ] {beffa840-3598-4df5-b626-15613dbd2af8} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: String: In scope SELECT YYYYMMDDhhmmssToDateTime64('2023-09-11', 'invalid precision'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b96d6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:17.964937 [ 10930 ] {916ce428-ab14-4fb0-b95a-e4d82c2e8e4f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'precision' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: const String, got: UInt8: In scope SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56136) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764787a 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b96d6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:17.965716 [ 10930 ] {916ce428-ab14-4fb0-b95a-e4d82c2e8e4f} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'precision' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: const String, got: UInt8: In scope SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764787a 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b96d6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:55:18.219503 [ 10930 ] {9fea6e5f-a7a6-4bf8-9cc5-432aad3dcdb9} executeQuery: Code: 36. DB::Exception: Cannot load time zone invalid tz: In scope SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 'invalid tz'). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56136) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 'invalid tz');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000000f9ee668 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x000000000f9e9047 6. ./src/Common/DateLUT.h:0: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000016e45ab5 7. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:23: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000016e45fbd 8. std::shared_ptr std::allocate_shared[abi:v15007], unsigned int&, String&, void>(std::allocator const&, unsigned int&, String&) @ 0x000000000c0b9b51 9. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b97d6 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 2025.10.23 23:55:18.220259 [ 10930 ] {9fea6e5f-a7a6-4bf8-9cc5-432aad3dcdb9} TCPHandler: Code: 36. DB::Exception: Cannot load time zone invalid tz: In scope SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 'invalid tz'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000000f9ee668 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x000000000f9e9047 6. ./src/Common/DateLUT.h:0: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000016e45ab5 7. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:23: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000016e45fbd 8. std::shared_ptr std::allocate_shared[abi:v15007], unsigned int&, String&, void>(std::allocator const&, unsigned int&, String&) @ 0x000000000c0b9b51 9. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b97d6 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 2025.10.23 23:55:18.230183 [ 10930 ] {189a6ad8-54d2-4fd7-89e6-816d66ea2426} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 4 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 'Europe/Berlin', 'no more args'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56136) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 'Europe/Berlin', 'no more args');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000007649e6c 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007647bf1 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b96d6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.23 23:55:18.231000 [ 10930 ] {189a6ad8-54d2-4fd7-89e6-816d66ea2426} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 4 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 'Europe/Berlin', 'no more args'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000007649e6c 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007647bf1 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c0b96d6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.23 23:55:19.278554 [ 10930 ] {0a4750a6-cbfb-4119-976d-d729b4d68b99} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime64 must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime64(nan). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56136) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64(NaN);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c0b940f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.23 23:55:19.279804 [ 10930 ] {0a4750a6-cbfb-4119-976d-d729b4d68b99} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime64 must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime64(nan). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c0b940f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.23 23:55:19.289938 [ 10930 ] {3b56df7d-96f1-422a-9b0e-47db299f83b9} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime64 must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime64(inf). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56136) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64(Inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c0b940f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.23 23:55:19.290604 [ 10930 ] {3b56df7d-96f1-422a-9b0e-47db299f83b9} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime64 must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime64(inf). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c0b940f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.23 23:55:19.299133 [ 10930 ] {dd0d396f-6e62-42e9-8b33-98cb4fd7e170} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime64 must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime64(-inf). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56136) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64(-Inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c0b940f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.23 23:55:19.299843 [ 10930 ] {dd0d396f-6e62-42e9-8b33-98cb4fd7e170} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime64 must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime64(-inf). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c0b940f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.23 23:55:24.527634 [ 10931 ] {2a6b0e32-8d78-459e-9d1e-1f96a117fa79} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:49498) (comment: 01220_scalar_optimization_in_alter.sql) (in query: CREATE TABLE cdp_segments (`seg_id` String, `mid_seqs` AggregateFunction(groupBitmap, UInt32)) ENGINE = ReplacingMergeTree ORDER BY seg_id SETTINGS index_granularity = 58979, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.45038923621177673, replace_long_file_name_to_hash = false, max_file_name_length = 15, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 163862354, compact_parts_max_granules_to_buffer = 236, compact_parts_merge_max_bytes_to_prefetch_part = 4558583, merge_max_block_size = 10149, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 9899631403, index_granularity_bytes = 20006294, concurrent_part_removal_threshold = 53, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 41070, primary_key_compress_block_size = 46024), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 2025.10.23 23:55:24.529662 [ 10931 ] {2a6b0e32-8d78-459e-9d1e-1f96a117fa79} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 2025.10.23 23:55:24.579459 [ 10930 ] {b614e5fb-eadf-4238-b712-3fb253c8c42b} executeQuery: Code: 43. DB::Exception: Unsupported types for IN. First argument type Tuple(UInt8, UInt8). Second argument type UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:49482) (comment: 02370_analyzer_in_function.sql) (in query: SELECT (1, 2) IN 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Analyzer/SetUtils.cpp:0: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000017531c53 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3398: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c23b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 16. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 2025.10.23 23:55:24.580612 [ 10930 ] {b614e5fb-eadf-4238-b712-3fb253c8c42b} TCPHandler: Code: 43. DB::Exception: Unsupported types for IN. First argument type Tuple(UInt8, UInt8). Second argument type UInt8. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Analyzer/SetUtils.cpp:0: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000017531c53 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3398: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c23b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 16. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 2025.10.23 23:55:25.044597 [ 10930 ] {d403ef01-d323-4776-9b34-1c55999915eb} executeQuery: Code: 124. DB::Exception: Invalid type in set. Expected tuple, got Array. (INCORRECT_ELEMENT_OF_SET) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:49482) (comment: 02370_analyzer_in_function.sql) (in query: SELECT (1, 2) IN [1];), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000000773f3a0 4. ./build_docker/./src/Analyzer/SetUtils.cpp:98: DB::Block DB::(anonymous namespace)::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, bool) @ 0x0000000017532d23 5. ./build_docker/./src/Analyzer/SetUtils.cpp:0: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x00000000175308bd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3398: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c23b7 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.23 23:55:25.045778 [ 10930 ] {d403ef01-d323-4776-9b34-1c55999915eb} TCPHandler: Code: 124. DB::Exception: Invalid type in set. Expected tuple, got Array. (INCORRECT_ELEMENT_OF_SET), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000000773f3a0 4. ./build_docker/./src/Analyzer/SetUtils.cpp:98: DB::Block DB::(anonymous namespace)::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, bool) @ 0x0000000017532d23 5. ./build_docker/./src/Analyzer/SetUtils.cpp:0: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x00000000175308bd 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3398: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c23b7 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.23 23:55:25.057928 [ 10930 ] {b6a02505-453d-4151-b09a-8724ff8bdffb} executeQuery: Code: 43. DB::Exception: Unsupported types for IN. First argument type Tuple(UInt8, UInt8). Second argument type Tuple(Tuple(Tuple(UInt8, UInt8), Tuple(UInt8, UInt8)), Tuple(Tuple(UInt8, UInt8), Tuple(UInt8, UInt8))). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:49482) (comment: 02370_analyzer_in_function.sql) (in query: SELECT (1, 2) IN (((1, 2), (1, 2)), ((1, 2), (1, 2)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Analyzer/SetUtils.cpp:0: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000017531c53 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3398: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c23b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 16. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 2025.10.23 23:55:25.058916 [ 10930 ] {b6a02505-453d-4151-b09a-8724ff8bdffb} TCPHandler: Code: 43. DB::Exception: Unsupported types for IN. First argument type Tuple(UInt8, UInt8). Second argument type Tuple(Tuple(Tuple(UInt8, UInt8), Tuple(UInt8, UInt8)), Tuple(Tuple(UInt8, UInt8), Tuple(UInt8, UInt8))). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Analyzer/SetUtils.cpp:0: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000017531c53 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3398: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c23b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 16. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 2025.10.23 23:55:25.107702 [ 10930 ] {789eb322-ed9f-461f-8e86-c1e448f20e14} executeQuery: Code: 43. DB::Exception: Unsupported types for IN. First argument type Tuple(UInt8, UInt8). Second argument type Array(Tuple(Tuple(UInt8, UInt8), Tuple(UInt8, UInt8))). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:49482) (comment: 02370_analyzer_in_function.sql) (in query: SELECT (1, 2) IN [((1, 2), (1, 2)), ((1, 2), (1, 2))];), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Analyzer/SetUtils.cpp:0: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000017531c53 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3398: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c23b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 16. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 2025.10.23 23:55:25.108873 [ 10930 ] {789eb322-ed9f-461f-8e86-c1e448f20e14} TCPHandler: Code: 43. DB::Exception: Unsupported types for IN. First argument type Tuple(UInt8, UInt8). Second argument type Array(Tuple(Tuple(UInt8, UInt8), Tuple(UInt8, UInt8))). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Analyzer/SetUtils.cpp:0: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000017531c53 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3398: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c23b7 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 16. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 2025.10.23 23:55:26.018079 [ 3013 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:55:26.190277 [ 10932 ] {59b6a336-5194-4dd5-a902-74e8d02b50c0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=724). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:49540) (comment: 00481_reading_from_last_granula.sql) (in query: INSERT INTO tab_00481 SELECT today() as date, number as value, '' as s, toFixedString('', 16) as m from system.numbers limit 42;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f2d53 8. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000001a1ec1ec 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:55:26.193429 [ 10932 ] {59b6a336-5194-4dd5-a902-74e8d02b50c0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=724). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f2d53 8. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000001a1ec1ec 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:55:31.962463 [ 10932 ] {4eb6ad8e-261f-4252-a35c-4b196c133041} executeQuery: Code: 456. DB::Exception: Substitution `s` is not set. (UNKNOWN_QUERY_PARAMETER) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:49344) (comment: 00954_client_prepared_statements.sh) (in query: SELECT {s:String}), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::getParamValue(String const&) @ 0x00000000181fd5f9 5. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x00000000181fc030 6. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:38: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000181fbed6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000181fd421 8. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000181fbfb6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000181fd421 10. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000181fbfb6 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000181fd421 12. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000181fbfb6 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000181fd421 14. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000181fbfb6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:847: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821d728 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:55:31.963703 [ 10932 ] {4eb6ad8e-261f-4252-a35c-4b196c133041} TCPHandler: Code: 456. DB::Exception: Substitution `s` is not set. (UNKNOWN_QUERY_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::getParamValue(String const&) @ 0x00000000181fd5f9 5. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:0: DB::ReplaceQueryParameterVisitor::visitQueryParameter(std::shared_ptr&) @ 0x00000000181fc030 6. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:38: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000181fbed6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000181fd421 8. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000181fbfb6 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000181fd421 10. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000181fbfb6 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000181fd421 12. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000181fbfb6 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplaceQueryParameterVisitor::visitChildren(std::shared_ptr&) @ 0x00000000181fd421 14. ./build_docker/./src/Interpreters/ReplaceQueryParameterVisitor.cpp:48: DB::ReplaceQueryParameterVisitor::visit(std::shared_ptr&) @ 0x00000000181fbfb6 15. ./build_docker/./src/Interpreters/executeQuery.cpp:847: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001821d728 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:55:33.659090 [ 10933 ] {b0184fac-1eef-4a06-9a51-654bd33be324} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=724). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:49354) (comment: 00725_ipv4_ipv6_domains.sql) (in query: SELECT 'FFFF:FFFF:FFFF:FFFF:FFFF:FFFF:FFFF:FFFF is ipv6 string: ', isIPv6String('FFFF:FFFF:FFFF:FFFF:FFFF:FFFF:FFFF:FFFF');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:55:33.660451 [ 10933 ] {b0184fac-1eef-4a06-9a51-654bd33be324} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=724). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:55:33.745601 [ 2687 ] {1d9a4f13-ef4c-465c-866f-ce64e2137152} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57710) (comment: 00725_ipv4_ipv6_domains.sql) (in query: DROP DATABASE IF EXISTS test_g6z65xtp ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:55:33.746493 [ 2687 ] {1d9a4f13-ef4c-465c-866f-ce64e2137152} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:55:33.774992 [ 10933 ] {24ea1689-b29f-4cd1-8918-f8432cf92535} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57720) (comment: 00725_ipv4_ipv6_domains.sql) (in query: DROP DATABASE IF EXISTS test_g6z65xtp ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:55:33.776443 [ 10933 ] {24ea1689-b29f-4cd1-8918-f8432cf92535} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:55:33.790511 [ 10936 ] {e5150dea-fe3c-4fd8-8742-d3a2220891b0} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57722) (comment: 00725_ipv4_ipv6_domains.sql) (in query: DROP DATABASE IF EXISTS test_g6z65xtp ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:55:33.792792 [ 10936 ] {e5150dea-fe3c-4fd8-8742-d3a2220891b0} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:55:33.810478 [ 10933 ] {57111ecc-6dc2-4597-b90c-dc6d649c7587} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57732) (comment: 00725_ipv4_ipv6_domains.sql) (in query: DROP DATABASE IF EXISTS test_g6z65xtp ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:55:33.812064 [ 10933 ] {57111ecc-6dc2-4597-b90c-dc6d649c7587} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:55:39.741076 [ 4099 ] {521790da-4342-4dde-8d9c-86e0f17c364a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=723). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:49422) (comment: 02479_nullable_primary_key_non_first_column.sql) (in query: select * from test_table where B is null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:55:39.742419 [ 4099 ] {521790da-4342-4dde-8d9c-86e0f17c364a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=723). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:55:43.058109 [ 3016 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:55:45.019237 [ 2936 ] {} RefreshTask: Refresh view test_13.e failed (attempt 1/1): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 15. ./src/Interpreters/InterpreterCreateQuery.h:29: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x0000000017c5085a 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1535: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4da81 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 18. ./build_docker/./src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x00000000192bab92 19. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:380: DB::RefreshTask::executeRefreshUnlocked(bool) @ 0x0000000019ff6028 20. ./contrib/llvm-project/libcxx/include/__mutex_base:207: DB::RefreshTask::refreshTask() @ 0x0000000019ff46e8 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019ff7522 22. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 24. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:55:46.731371 [ 4099 ] {452bbf98-b284-4a30-b967-1ef435e223c8} PushingToViews: Failed to push block to view test_1.test_mv_pk (3e721a93-38f3-4344-b5d9-41e3badf9b86), Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test 2025.10.23 23:55:47.117927 [ 4099 ] {452bbf98-b284-4a30-b967-1ef435e223c8} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test. (UNKNOWN_IDENTIFIER) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:49566) (comment: 03041_dynamic_type_check_table.sh) (in query: insert into test select number, number from numbers(3)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc2d4c 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000001a795ab5 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a799501 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000017d48f54 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d49eb8 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4c3d4 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f801 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:55:47.122646 [ 4099 ] {452bbf98-b284-4a30-b967-1ef435e223c8} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc2d4c 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000001a795ab5 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a799501 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000017d48f54 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d49eb8 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4c3d4 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f801 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:55:49.612226 [ 10419 ] {3992ab99-f448-4c14-b664-6f1e34ec2abc} PushingToViews: Failed to push block to view test_1.test_mv_pk (3e721a93-38f3-4344-b5d9-41e3badf9b86), Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test 2025.10.23 23:55:49.614372 [ 10419 ] {3992ab99-f448-4c14-b664-6f1e34ec2abc} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test. (UNKNOWN_IDENTIFIER) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:46834) (comment: 03041_dynamic_type_check_table.sh) (in query: insert into test select number, number, number from numbers(3, 3)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc2d4c 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000001a795ab5 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a799501 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000017d48f54 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d49eb8 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4c3d4 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f801 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:55:49.616729 [ 10419 ] {3992ab99-f448-4c14-b664-6f1e34ec2abc} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc2d4c 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000001a795ab5 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a799501 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000017d48f54 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d49eb8 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4c3d4 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f801 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:55:50.261132 [ 10385 ] {6e94364f-b6c8-46e2-a3ea-70d851e8cce4} PushingToViews: Failed to push block to view test_1.test_mv_pk (3e721a93-38f3-4344-b5d9-41e3badf9b86), Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test 2025.10.23 23:55:50.263322 [ 10385 ] {6e94364f-b6c8-46e2-a3ea-70d851e8cce4} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test. (UNKNOWN_IDENTIFIER) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:46836) (comment: 03041_dynamic_type_check_table.sh) (in query: insert into test select number, number, 'str_' || toString(number) from numbers(6, 3)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc2d4c 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000001a795ab5 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a799501 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000017d48f54 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d49eb8 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4c3d4 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f801 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:55:50.265322 [ 10385 ] {6e94364f-b6c8-46e2-a3ea-70d851e8cce4} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc2d4c 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000001a795ab5 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a799501 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000017d48f54 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d49eb8 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4c3d4 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f801 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:55:50.982549 [ 10385 ] {99bb6b6f-908c-4b66-ad3e-9f4d6ba45a92} PushingToViews: Failed to push block to view test_1.test_mv_pk (3e721a93-38f3-4344-b5d9-41e3badf9b86), Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test 2025.10.23 23:55:51.041513 [ 10385 ] {99bb6b6f-908c-4b66-ad3e-9f4d6ba45a92} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test. (UNKNOWN_IDENTIFIER) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:46850) (comment: 03041_dynamic_type_check_table.sh) (in query: insert into test select number, number, NULL from numbers(9, 3)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc2d4c 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000001a795ab5 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a799501 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000017d48f54 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d49eb8 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4c3d4 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f801 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:55:51.044206 [ 10385 ] {99bb6b6f-908c-4b66-ad3e-9f4d6ba45a92} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc2d4c 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000001a795ab5 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a799501 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000017d48f54 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d49eb8 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4c3d4 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f801 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:55:51.761024 [ 10419 ] {6f9d5bd5-e85c-4447-8810-ed482fc124dc} PushingToViews: Failed to push block to view test_1.test_mv_pk (3e721a93-38f3-4344-b5d9-41e3badf9b86), Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test 2025.10.23 23:55:51.763228 [ 10419 ] {6f9d5bd5-e85c-4447-8810-ed482fc124dc} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test. (UNKNOWN_IDENTIFIER) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:46856) (comment: 03041_dynamic_type_check_table.sh) (in query: insert into test select number, number, multiIf(number % 3 == 0, number, number % 3 == 1, 'str_' || toString(number), NULL) from numbers(12, 3)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc2d4c 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000001a795ab5 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a799501 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000017d48f54 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d49eb8 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4c3d4 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f801 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:55:51.765477 [ 10419 ] {6f9d5bd5-e85c-4447-8810-ed482fc124dc} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc2d4c 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000001a795ab5 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a799501 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000017d48f54 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d49eb8 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4c3d4 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f801 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:55:52.242134 [ 10936 ] {a78190a1-1555-403f-9d55-26224263a421} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:60690) (comment: 01338_long_select_and_alter_zookeeper.sh) (in query: DROP DATABASE IF EXISTS test_tjb78vpb ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:55:52.243634 [ 10936 ] {a78190a1-1555-403f-9d55-26224263a421} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:55:54.865370 [ 10929 ] {64a67273-cdc6-4337-b6a6-d65dbe5b8ef4} executeQuery: Code: 57. DB::Exception: Table test_1.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:46938) (comment: 03041_dynamic_type_check_table.sh) (in query: CREATE TABLE test (`x` UInt64, `y` UInt64) ENGINE = MergeTree ORDER BY x SETTINGS min_rows_for_wide_part = 1, min_bytes_for_wide_part = 1, index_granularity = 63266, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 115, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 400795140, compact_parts_max_granules_to_buffer = 48, compact_parts_merge_max_bytes_to_prefetch_part = 17435059, merge_max_block_size = 20763, old_parts_lifetime = 278., prefer_fetch_merged_part_size_threshold = 4302003434, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 264688748, index_granularity_bytes = 19871961, concurrent_part_removal_threshold = 68, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 75375, primary_key_compress_block_size = 85638), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:55:54.867163 [ 10929 ] {64a67273-cdc6-4337-b6a6-d65dbe5b8ef4} TCPHandler: Code: 57. DB::Exception: Table test_1.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:55:55.834752 [ 10419 ] {faaacd85-2d53-47d0-9229-0a85702dcd9d} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 2 and result: 3). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:46944) (comment: 03041_dynamic_type_check_table.sh) (in query: insert into test select number, number from numbers(3)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000008889946 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x000000001740896a 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4bc64 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f801 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:55:55.836769 [ 10419 ] {faaacd85-2d53-47d0-9229-0a85702dcd9d} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 2 and result: 3). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000008889946 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x000000001740896a 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4bc64 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f801 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:55:56.775422 [ 10419 ] {c4e6f0fa-c1a1-498a-8f11-4f62720f43c2} executeQuery: Code: 15. DB::Exception: Cannot add column `d`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:46952) (comment: 03041_dynamic_type_check_table.sh) (in query: alter table test add column d Dynamic(max_types=2) settings mutations_sync=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000190edb90 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c296ab 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:55:56.777131 [ 10419 ] {c4e6f0fa-c1a1-498a-8f11-4f62720f43c2} TCPHandler: Code: 15. DB::Exception: Cannot add column `d`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000190edb90 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c296ab 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:55:58.575231 [ 10419 ] {a12fbe09-9bd7-458c-bc88-eda4e332e50c} PushingToViews: Failed to push block to view test_1.test_mv_pk (3e721a93-38f3-4344-b5d9-41e3badf9b86), Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test 2025.10.23 23:55:58.577076 [ 10419 ] {a12fbe09-9bd7-458c-bc88-eda4e332e50c} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test. (UNKNOWN_IDENTIFIER) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47012) (comment: 03041_dynamic_type_check_table.sh) (in query: insert into test select number, number, number from numbers(3, 3)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc2d4c 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000001a795ab5 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a799501 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000017d48f54 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d49eb8 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4c3d4 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f801 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:55:58.579197 [ 10419 ] {a12fbe09-9bd7-458c-bc88-eda4e332e50c} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc2d4c 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000001a795ab5 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a799501 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000017d48f54 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d49eb8 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4c3d4 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f801 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:55:59.212009 [ 10419 ] {16438e51-3337-461e-953d-845d264292a8} PushingToViews: Failed to push block to view test_1.test_mv_pk (3e721a93-38f3-4344-b5d9-41e3badf9b86), Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test 2025.10.23 23:55:59.213937 [ 10419 ] {16438e51-3337-461e-953d-845d264292a8} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test. (UNKNOWN_IDENTIFIER) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59014) (comment: 03041_dynamic_type_check_table.sh) (in query: insert into test select number, number, 'str_' || toString(number) from numbers(6, 3)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc2d4c 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000001a795ab5 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a799501 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000017d48f54 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d49eb8 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4c3d4 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f801 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:55:59.216265 [ 10419 ] {16438e51-3337-461e-953d-845d264292a8} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc2d4c 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000001a795ab5 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a799501 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000017d48f54 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d49eb8 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4c3d4 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f801 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:55:59.792886 [ 10419 ] {83886dba-6447-4b8f-904e-716d2296a793} PushingToViews: Failed to push block to view test_1.test_mv_pk (3e721a93-38f3-4344-b5d9-41e3badf9b86), Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test 2025.10.23 23:55:59.794669 [ 10419 ] {83886dba-6447-4b8f-904e-716d2296a793} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test. (UNKNOWN_IDENTIFIER) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59030) (comment: 03041_dynamic_type_check_table.sh) (in query: insert into test select number, number, NULL from numbers(9, 3)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc2d4c 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000001a795ab5 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a799501 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000017d48f54 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d49eb8 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4c3d4 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f801 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:55:59.796825 [ 10419 ] {83886dba-6447-4b8f-904e-716d2296a793} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc2d4c 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000001a795ab5 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a799501 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000017d48f54 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d49eb8 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4c3d4 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f801 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:56:00.427009 [ 10929 ] {1c046961-e26a-4878-b6d8-3197d9a61925} PushingToViews: Failed to push block to view test_1.test_mv_pk (3e721a93-38f3-4344-b5d9-41e3badf9b86), Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test 2025.10.23 23:56:00.429094 [ 10929 ] {1c046961-e26a-4878-b6d8-3197d9a61925} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test. (UNKNOWN_IDENTIFIER) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59050) (comment: 03041_dynamic_type_check_table.sh) (in query: insert into test select number, number, multiIf(number % 3 == 0, number, number % 3 == 1, 'str_' || toString(number), NULL) from numbers(12, 3)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc2d4c 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000001a795ab5 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a799501 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000017d48f54 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d49eb8 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4c3d4 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f801 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:56:00.431639 [ 10929 ] {1c046961-e26a-4878-b6d8-3197d9a61925} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'value' in scope SELECT value, id FROM test_1.test. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc2d4c 14. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:0: DB::generateViewChain(std::shared_ptr, DB::StorageID const&, std::shared_ptr, DB::Chain&, std::shared_ptr, std::shared_ptr, bool, DB::Block const&, bool) @ 0x000000001a795ab5 15. ./contrib/llvm-project/libcxx/include/optional:344: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a799501 16. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000017d48f54 17. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d49eb8 18. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4c3d4 19. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f801 20. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:56:03.431223 [ 5101 ] {} test_tl2j6cp3.ds_1_1 (7aa75574-6d39-44c2-81ac-2219217e1cd5): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.10.23 23:56:04.013490 [ 5101 ] {} DatabaseCatalog: Cannot drop table test_tl2j6cp3.ds_1_1 (7aa75574-6d39-44c2-81ac-2219217e1cd5). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199db57d 9. ./contrib/llvm-project/libcxx/include/__hash_table:935: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x00000000199d8d27 10. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x00000000199e0e99 11. ./build_docker/./src/Storages/StorageMergeTree.cpp:317: DB::StorageMergeTree::drop() @ 0x0000000019e54b04 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000176a79f9 13. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000176b3544 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000160e3d18 15. ./contrib/llvm-project/libcxx/include/future:1694: std::__packaged_task_func>, std::function>::operator()(std::function&&, Priority)::'lambda'(), std::allocator>, std::function>::operator()(std::function&&, Priority)::'lambda'()>, void ()>::operator()() @ 0x00000000160e3c1e 16. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000101feb95 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000160e4e4d 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 23. __tsan_thread_start_func @ 0x000000000758df2f 24. ? @ 0x00007f7c69445ac3 25. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:56:04.260007 [ 10419 ] {e3767561-8c6c-4807-95c2-626cdcec0a13} executeQuery: Code: 57. DB::Exception: Table test_1.`01154_test` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59124) (comment: 01554_bloom_filter_index_big_integer_uuid.sql) (in query: CREATE TABLE `01154_test` (`x` UInt256, INDEX ix_x x TYPE bloom_filter(0.01) GRANULARITY 1) ENGINE = MergeTree ORDER BY x SETTINGS index_granularity = 8192, min_bytes_for_wide_part = 451164483, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 42, min_bytes_for_full_part_storage = 336776690, compact_parts_max_bytes_to_buffer = 95208085, compact_parts_max_granules_to_buffer = 161, compact_parts_merge_max_bytes_to_prefetch_part = 15610262, merge_max_block_size = 23909, old_parts_lifetime = 14., prefer_fetch_merged_part_size_threshold = 9976766330, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 250406518, index_granularity_bytes = 9385097, concurrent_part_removal_threshold = 64, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 46110, primary_key_compress_block_size = 78987), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:56:04.261690 [ 10419 ] {e3767561-8c6c-4807-95c2-626cdcec0a13} TCPHandler: Code: 57. DB::Exception: Table test_1.`01154_test` already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:56:08.922056 [ 10419 ] {06d1dff3-46f4-47d5-adbc-c69a430f2471} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59190) (comment: 01018_dictionaries_from_dictionaries.sql) (in query: SELECT count(*) FROM database_for_dict.dict2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:56:08.923464 [ 10419 ] {06d1dff3-46f4-47d5-adbc-c69a430f2471} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:56:09.472174 [ 10385 ] {b7dd4ea6-7ed6-42d0-b2c8-2687f46b381d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:52992) (comment: 02972_insert_deduplication_token_hierarchical_inserts.sql) (in query: DROP DATABASE IF EXISTS test_tl2j6cp3 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:56:09.474561 [ 10385 ] {b7dd4ea6-7ed6-42d0-b2c8-2687f46b381d} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:56:09.518019 [ 10929 ] {b4b46a1a-5b3e-4d2c-9a01-eeed5bc32d0f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:52998) (comment: 02972_insert_deduplication_token_hierarchical_inserts.sql) (in query: DROP DATABASE IF EXISTS test_tl2j6cp3 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:56:09.520498 [ 10929 ] {b4b46a1a-5b3e-4d2c-9a01-eeed5bc32d0f} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:56:09.614044 [ 3875 ] {190eacdf-dd16-4602-b7a8-9e5b8252604a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53000) (comment: 02972_insert_deduplication_token_hierarchical_inserts.sql) (in query: DROP DATABASE IF EXISTS test_tl2j6cp3 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:56:09.618556 [ 3875 ] {190eacdf-dd16-4602-b7a8-9e5b8252604a} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:56:09.633960 [ 10929 ] {db4e5a79-9f03-48d4-984f-3e558ce08312} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53016) (comment: 02972_insert_deduplication_token_hierarchical_inserts.sql) (in query: DROP DATABASE IF EXISTS test_tl2j6cp3 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:56:09.636111 [ 10929 ] {db4e5a79-9f03-48d4-984f-3e558ce08312} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:56:09.651775 [ 3875 ] {be6425c9-7407-4a45-b2c4-2319897313cf} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53018) (comment: 02972_insert_deduplication_token_hierarchical_inserts.sql) (in query: DROP DATABASE IF EXISTS test_tl2j6cp3 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:56:09.653066 [ 3875 ] {be6425c9-7407-4a45-b2c4-2319897313cf} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:56:09.880599 [ 10419 ] {3f8a45ce-095d-464a-b42a-1d9a5e4b8b53} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(8, 8). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50304) (comment: 01178_int_field_to_decimal.sql) (in query: select d from values('d Decimal(8, 8)', 0, 1) where d not in (-1, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x00000000181d6e45 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:235: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181cfefd 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181ce369 7. ./src/Core/Field.h:459: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181d24ee 8. ./contrib/llvm-project/libcxx/include/vector:1491: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015e8ee03 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 10. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 30. __tsan_thread_start_func @ 0x000000000758df2f 31. ? @ 0x00007f7c69445ac3 2025.10.23 23:56:09.881305 [ 10419 ] {3f8a45ce-095d-464a-b42a-1d9a5e4b8b53} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(8, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x00000000181d6e45 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:235: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181cfefd 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181ce369 7. ./src/Core/Field.h:459: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181d24ee 8. ./contrib/llvm-project/libcxx/include/vector:1491: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015e8ee03 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 10. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 30. __tsan_thread_start_func @ 0x000000000758df2f 31. ? @ 0x00007f7c69445ac3 2025.10.23 23:56:09.890656 [ 10419 ] {1fca0a8c-066e-43b5-99b5-1559430596b6} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(8, 8). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50304) (comment: 01178_int_field_to_decimal.sql) (in query: select d from values('d Decimal(8, 8)', 0, 2) where d not in (1, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x00000000181d6e45 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:235: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181cfefd 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181ce369 7. ./src/Core/Field.h:459: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181d24ee 8. ./contrib/llvm-project/libcxx/include/vector:1491: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015e8ee03 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 10. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 30. __tsan_thread_start_func @ 0x000000000758df2f 31. ? @ 0x00007f7c69445ac3 2025.10.23 23:56:09.891377 [ 10419 ] {1fca0a8c-066e-43b5-99b5-1559430596b6} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(8, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x00000000181d6e45 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:235: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181cfefd 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181ce369 7. ./src/Core/Field.h:459: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181d24ee 8. ./contrib/llvm-project/libcxx/include/vector:1491: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015e8ee03 9. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 10. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 30. __tsan_thread_start_func @ 0x000000000758df2f 31. ? @ 0x00007f7c69445ac3 2025.10.23 23:56:10.242212 [ 3875 ] {db7ecd42-a04f-4a75-9361-d8571c25337c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=22, jobs=22). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50312) (comment: 02212_cte_and_table_alias.sql) (in query: WITH t AS ( SELECT number AS n FROM numbers(10000) ) SELECT count(*) FROM t AS a WHERE a.n < 5000;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f5511 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:56:10.244967 [ 3875 ] {db7ecd42-a04f-4a75-9361-d8571c25337c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=22, jobs=22). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f5511 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:56:10.405967 [ 10419 ] {911fef67-1617-4877-82ce-fb4432c1ac1b} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(9, 8). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50304) (comment: 01178_int_field_to_decimal.sql) (in query: select d from values('d Decimal(9, 8)', 0, 3) where d not in (-9223372036854775808, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x00000000181d6ef3 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:235: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181cfefd 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181ce369 7. ./src/Core/Field.h:455: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x00000000181d2921 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000017530ca2 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000001753f3e6 10. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000001753eed1 11. ./build_docker/./src/Planner/CollectSets.cpp:128: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000001753ee16 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc8bd1 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:56:10.407679 [ 10419 ] {911fef67-1617-4877-82ce-fb4432c1ac1b} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(9, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x00000000181d6ef3 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:235: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181cfefd 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181ce369 7. ./src/Core/Field.h:455: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x00000000181d2921 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000017530ca2 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000001753f3e6 10. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000001753eed1 11. ./build_docker/./src/Planner/CollectSets.cpp:128: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000001753ee16 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc8bd1 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:56:10.905014 [ 10419 ] {28c37a4b-2634-4698-8046-7a3519cc2ccc} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(9, 8). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50304) (comment: 01178_int_field_to_decimal.sql) (in query: select d from values('d Decimal(9, 8)', 0, 4) where d not in (18446744073709551615, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x00000000181d6e45 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:235: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181cfefd 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181ce369 7. ./src/Core/Field.h:455: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x00000000181d2921 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000017530ca2 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000001753f3e6 10. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000001753eed1 11. ./build_docker/./src/Planner/CollectSets.cpp:128: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000001753ee16 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc8bd1 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:56:10.906003 [ 10419 ] {28c37a4b-2634-4698-8046-7a3519cc2ccc} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(9, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x00000000181d6e45 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:235: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181cfefd 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181ce369 7. ./src/Core/Field.h:455: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x00000000181d2921 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000017530ca2 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000001753f3e6 10. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000001753eed1 11. ./build_docker/./src/Planner/CollectSets.cpp:128: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000001753ee16 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc8bd1 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:56:11.061666 [ 10419 ] {13b355b1-3b42-4f6f-b298-5428fd6b9921} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(18, 8). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50304) (comment: 01178_int_field_to_decimal.sql) (in query: select d from values('d Decimal(18, 8)', 0, 5) where d not in (-9223372036854775808, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x00000000181d7a9f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:236: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181d0190 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181ce369 7. ./src/Core/Field.h:455: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x00000000181d2921 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000017530ca2 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000001753f3e6 10. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000001753eed1 11. ./build_docker/./src/Planner/CollectSets.cpp:128: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000001753ee16 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc8bd1 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:56:11.062386 [ 10419 ] {13b355b1-3b42-4f6f-b298-5428fd6b9921} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(18, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x00000000181d7a9f 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:236: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181d0190 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181ce369 7. ./src/Core/Field.h:455: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x00000000181d2921 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000017530ca2 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000001753f3e6 10. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000001753eed1 11. ./build_docker/./src/Planner/CollectSets.cpp:128: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000001753ee16 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc8bd1 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:56:11.310411 [ 10419 ] {f6d519f3-2cb8-455b-8360-7989ba943b58} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(18, 8). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50304) (comment: 01178_int_field_to_decimal.sql) (in query: select d from values('d Decimal(18, 8)', 0, 6) where d not in (18446744073709551615, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x00000000181d79f1 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:236: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181d0190 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181ce369 7. ./src/Core/Field.h:455: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x00000000181d2921 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000017530ca2 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000001753f3e6 10. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000001753eed1 11. ./build_docker/./src/Planner/CollectSets.cpp:128: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000001753ee16 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc8bd1 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:56:11.312998 [ 10419 ] {f6d519f3-2cb8-455b-8360-7989ba943b58} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(18, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x00000000181d79f1 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:236: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181d0190 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181ce369 7. ./src/Core/Field.h:455: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x00000000181d2921 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000017530ca2 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000001753f3e6 10. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000001753eed1 11. ./build_docker/./src/Planner/CollectSets.cpp:128: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000001753ee16 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc8bd1 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:56:11.824172 [ 10419 ] {724752ed-91ee-4288-9837-efebf3e14a72} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(26, 8). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50304) (comment: 01178_int_field_to_decimal.sql) (in query: select d from values('d Decimal(26, 8)', 0, 7) where d not in (-9223372036854775808, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>>(DB::Field const&, DB::DataTypeDecimal>> const&) @ 0x00000000181d85e9 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:237: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181d05e1 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181ce369 7. ./src/Core/Field.h:455: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x00000000181d2921 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000017530ca2 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000001753f3e6 10. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000001753eed1 11. ./build_docker/./src/Planner/CollectSets.cpp:128: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000001753ee16 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc8bd1 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:56:11.825398 [ 10419 ] {724752ed-91ee-4288-9837-efebf3e14a72} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(26, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>>(DB::Field const&, DB::DataTypeDecimal>> const&) @ 0x00000000181d85e9 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:237: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181d05e1 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181ce369 7. ./src/Core/Field.h:455: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x00000000181d2921 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000017530ca2 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000001753f3e6 10. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000001753eed1 11. ./build_docker/./src/Planner/CollectSets.cpp:128: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000001753ee16 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc8bd1 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:56:12.202017 [ 10419 ] {bf8bb72a-9151-4a4a-be28-2c1540a0d600} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(27, 8). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50304) (comment: 01178_int_field_to_decimal.sql) (in query: select d from values('d Decimal(27, 8)', 0, 8) where d not in (18446744073709551615, 0);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>>(DB::Field const&, DB::DataTypeDecimal>> const&) @ 0x00000000181d8640 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:237: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181d05e1 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181ce369 7. ./src/Core/Field.h:455: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x00000000181d2921 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000017530ca2 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000001753f3e6 10. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000001753eed1 11. ./build_docker/./src/Planner/CollectSets.cpp:128: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000001753ee16 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc8bd1 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:56:12.202725 [ 10419 ] {bf8bb72a-9151-4a4a-be28-2c1540a0d600} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(27, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::Field DB::(anonymous namespace)::convertDecimalType>>>(DB::Field const&, DB::DataTypeDecimal>> const&) @ 0x00000000181d8640 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:237: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181d05e1 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181ce369 7. ./src/Core/Field.h:455: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x00000000181d2921 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000017530ca2 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x000000001753f3e6 10. ./src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x000000001753eed1 11. ./build_docker/./src/Planner/CollectSets.cpp:128: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x000000001753ee16 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dc8bd1 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:56:13.587276 [ 10385 ] {8c7eee1e-2fd6-4838-b55c-ac4c37389f09} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=729). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:36278) (comment: 01005_rwr_shard_deadlock.sh) (in query: SELECT `__table1`.`x` AS `x` FROM `test_yn1dkn23`.`test1` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:56:13.589448 [ 10385 ] {8c7eee1e-2fd6-4838-b55c-ac4c37389f09} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=729). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:56:13.752630 [ 10932 ] {3165e613-bf0d-4473-affe-dc87666cc29e} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=729). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50370) (comment: 01005_rwr_shard_deadlock.sh) (in query: SELECT x FROM test1 WHERE x IN (SELECT x FROM remote('127.0.0.2', 'test_yn1dkn23', test1))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000faa1a74 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a058f02 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a063254 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0c20fe 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e35bdf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e356e0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e34243 2025.10.23 23:56:13.755982 [ 10932 ] {3165e613-bf0d-4473-affe-dc87666cc29e} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=729). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000faa1a74 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a058f02 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a063254 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0c20fe 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e35bdf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e356e0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e34243 2025.10.23 23:56:14.344792 [ 10931 ] {577b2b24-881d-4458-ae95-105a1b23affb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=726). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:36294) (comment: 01005_rwr_shard_deadlock.sh) (in query: SELECT `__table1`.`x` AS `x` FROM `test_yn1dkn23`.`test1` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:56:14.346356 [ 10931 ] {577b2b24-881d-4458-ae95-105a1b23affb} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=726). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:56:14.353346 [ 10932 ] {ac7fa635-a911-46fc-a57e-0a3072f26933} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=726). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50500) (comment: 01005_rwr_shard_deadlock.sh) (in query: SELECT x FROM test1 WHERE x IN (SELECT x FROM remote('127.0.0.2', 'test_yn1dkn23', test1))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000faa1a74 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a058f02 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a063254 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0c20fe 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e35bdf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e356e0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e34243 2025.10.23 23:56:14.385225 [ 10932 ] {ac7fa635-a911-46fc-a57e-0a3072f26933} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=726). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000faa1a74 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a058f02 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a063254 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0c20fe 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e35bdf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e356e0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e34243 2025.10.23 23:56:14.915982 [ 10931 ] {99e65502-3228-4f2c-9190-894e83497537} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50570) (comment: 01005_rwr_shard_deadlock.sh) (in query: SELECT x FROM test1 WHERE x IN (SELECT x FROM remote('127.0.0.2', 'test_yn1dkn23', test1))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:56:14.917338 [ 10931 ] {99e65502-3228-4f2c-9190-894e83497537} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:56:15.612383 [ 10931 ] {1c3827fe-8460-4af8-a777-c1a97fa20b39} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=723). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50682) (comment: 01005_rwr_shard_deadlock.sh) (in query: SELECT x FROM test1 WHERE x IN (SELECT x FROM remote('127.0.0.2', 'test_yn1dkn23', test1))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:56:15.615008 [ 10931 ] {1c3827fe-8460-4af8-a777-c1a97fa20b39} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=723). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:56:18.075433 [ 10931 ] {59af17f3-625d-4315-bc54-ab94173f5dd0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:51070) (comment: 01005_rwr_shard_deadlock.sh) (in query: SELECT x FROM test1 WHERE x IN (SELECT x FROM remote('127.0.0.2', 'test_yn1dkn23', test1))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:56:18.077128 [ 10931 ] {59af17f3-625d-4315-bc54-ab94173f5dd0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:56:18.336886 [ 10933 ] {2d032d60-9907-4f0a-8082-e3af57a170c2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=726). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:36476) (comment: 01005_rwr_shard_deadlock.sh) (in query: SELECT `__table1`.`x` AS `x` FROM `test_yn1dkn23`.`test1` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:56:18.338264 [ 10933 ] {2d032d60-9907-4f0a-8082-e3af57a170c2} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=726). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:56:18.344543 [ 10385 ] {92866a6f-5c3e-402b-be04-904ca5632c50} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=726). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:51110) (comment: 01005_rwr_shard_deadlock.sh) (in query: SELECT x FROM test1 WHERE x IN (SELECT x FROM remote('127.0.0.2', 'test_yn1dkn23', test1))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000faa1a74 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a058f02 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a063254 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0c20fe 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e35bdf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e356e0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e34243 2025.10.23 23:56:18.346514 [ 10385 ] {92866a6f-5c3e-402b-be04-904ca5632c50} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=726). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000faa1a74 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a058f02 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a063254 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0c20fe 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e35bdf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e356e0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e34243 2025.10.23 23:56:22.015885 [ 10932 ] {e7295272-50f7-49eb-b2c4-19ff49221eab} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:54704) (comment: 01005_rwr_shard_deadlock.sh) (in query: SELECT x FROM test1 WHERE x IN (SELECT x FROM remote('127.0.0.2', 'test_yn1dkn23', test1))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:56:22.016972 [ 10932 ] {e7295272-50f7-49eb-b2c4-19ff49221eab} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:56:23.043661 [ 3875 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:54830, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe5aed 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fbe4c7d 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fbe52f4 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:0: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a06adcf 6. DB::ReadBuffer::next() @ 0x0000000007b3717b 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001a1eb31a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:56:26.220092 [ 10929 ] {836ef76d-c946-42fa-b65d-3f66e212fd66} executeQuery: Code: 78. DB::Exception: Query has infile and was send directly to server. (UNKNOWN_TYPE_OF_QUERY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56734) (comment: 02009_from_infile.sh) (in query: INSERT INTO test_infile_url FROM INFILE '/tmp/clickhouse-test/0_stateless/test_infile.gz' FORMAT CSV), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Processors/Transforms/getSourceFromASTInsertQuery.cpp:0: DB::getInputFormatFromASTInsertQuery(std::shared_ptr const&, bool, DB::Block const&, std::shared_ptr, std::shared_ptr const&) @ 0x000000001a7ab129 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4e70e 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f7bc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:56:26.221869 [ 10929 ] {836ef76d-c946-42fa-b65d-3f66e212fd66} DynamicQueryHandler: Code: 78. DB::Exception: Query has infile and was send directly to server. (UNKNOWN_TYPE_OF_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Processors/Transforms/getSourceFromASTInsertQuery.cpp:0: DB::getInputFormatFromASTInsertQuery(std::shared_ptr const&, bool, DB::Block const&, std::shared_ptr, std::shared_ptr const&) @ 0x000000001a7ab129 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4e70e 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f7bc 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 10. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:56:31.217240 [ 10385 ] {26ee56a7-9a74-4634-aa25-ce7ea8ba2453} ~StorageFileSource: Failed to rename file /var/lib/clickhouse/user_files/02732_rename_after_processing_test_1/tmp5.csv: File /var/lib/clickhouse/user_files/02732_rename_after_processing_test_1/tmp.csv already exists 2025.10.23 23:56:31.787675 [ 10385 ] {3bcd8957-14d9-44db-8044-248931635346} ~StorageFileSource: Failed to rename file /var/lib/clickhouse/user_files/02732_rename_after_processing_test_1/tmp5.csv: File `/var/lib/clickhouse/tmp5.csv` is not inside `/var/lib/clickhouse/user_files/` 2025.10.23 23:56:32.966076 [ 10385 ] {862cfd8c-7487-4571-b47f-99eb235710c9} executeQuery: Code: 36. DB::Exception: Invalid renaming rule: Allowed placeholders only %a, %f, %e, %t, and %%. (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:54422) (comment: 02732_rename_after_processing.sh) (in query: SELECT COUNT(*) FROM file('02732_rename_after_processing_test_1/tmp5.csv')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Common/FileRenamer.cpp:77: DB::FileRenamer::validateRenamingRule(String const&, bool) @ 0x00000000191f480d 5. ./build_docker/./src/Common/FileRenamer.cpp:31: DB::FileRenamer::FileRenamer(String const&) @ 0x00000000191f3f8e 6. ./build_docker/./src/Storages/StorageFile.cpp:1035: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000191d0387 7. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x00000000191d0bcf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String const&, String, bool, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000015e84199 9. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:93: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x0000000015e81250 10. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:99: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015e85b95 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 12. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:56:32.967887 [ 10385 ] {862cfd8c-7487-4571-b47f-99eb235710c9} TCPHandler: Code: 36. DB::Exception: Invalid renaming rule: Allowed placeholders only %a, %f, %e, %t, and %%. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Common/FileRenamer.cpp:77: DB::FileRenamer::validateRenamingRule(String const&, bool) @ 0x00000000191f480d 5. ./build_docker/./src/Common/FileRenamer.cpp:31: DB::FileRenamer::FileRenamer(String const&) @ 0x00000000191f3f8e 6. ./build_docker/./src/Storages/StorageFile.cpp:1035: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000191d0387 7. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x00000000191d0bcf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String const&, String, bool, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000015e84199 9. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:93: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x0000000015e81250 10. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:99: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015e85b95 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 12. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:56:33.920123 [ 3875 ] {5dd07697-87d1-4309-87e2-814e4136a92f} executeQuery: Code: 36. DB::Exception: Invalid renaming rule: Odd number of consecutive percentage signs. (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:54460) (comment: 02732_rename_after_processing.sh) (in query: SELECT COUNT(*) FROM file('02732_rename_after_processing_test_1/tmp5.csv')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Common/FileRenamer.cpp:90: DB::FileRenamer::validateRenamingRule(String const&, bool) @ 0x00000000191f4898 5. ./build_docker/./src/Common/FileRenamer.cpp:31: DB::FileRenamer::FileRenamer(String const&) @ 0x00000000191f3f8e 6. ./build_docker/./src/Storages/StorageFile.cpp:1035: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000191d0387 7. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x00000000191d0bcf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String const&, String, bool, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000015e84199 9. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:93: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x0000000015e81250 10. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:99: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015e85b95 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 12. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:56:33.921727 [ 3875 ] {5dd07697-87d1-4309-87e2-814e4136a92f} TCPHandler: Code: 36. DB::Exception: Invalid renaming rule: Odd number of consecutive percentage signs. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Common/FileRenamer.cpp:90: DB::FileRenamer::validateRenamingRule(String const&, bool) @ 0x00000000191f4898 5. ./build_docker/./src/Common/FileRenamer.cpp:31: DB::FileRenamer::FileRenamer(String const&) @ 0x00000000191f3f8e 6. ./build_docker/./src/Storages/StorageFile.cpp:1035: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x00000000191d0387 7. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x00000000191d0bcf 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String const&, String, bool, DB::StorageFile::CommonArguments&, void>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x0000000015e84199 9. ./build_docker/./src/TableFunctions/TableFunctionFile.cpp:93: DB::TableFunctionFile::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&) const @ 0x0000000015e81250 10. ./build_docker/./src/TableFunctions/ITableFunctionFileLike.cpp:99: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015e85b95 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 12. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:56:35.471864 [ 10385 ] {c5957da6-8c79-41bb-9901-619d41916869} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Milli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:54528) (comment: 01277_toUnixTimestamp64.sql) (in query: -- Error cases SELECT toUnixTimestamp64Milli();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871a62c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008717669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:56:35.473068 [ 10385 ] {c5957da6-8c79-41bb-9901-619d41916869} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Milli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871a62c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008717669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:56:35.485411 [ 10385 ] {5d3e079e-0473-4192-8c81-c4f40bf6a26e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Micro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:54528) (comment: 01277_toUnixTimestamp64.sql) (in query: SELECT toUnixTimestamp64Micro();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871a62c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008717669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:56:35.486362 [ 10385 ] {5d3e079e-0473-4192-8c81-c4f40bf6a26e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Micro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871a62c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008717669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:56:35.497835 [ 10385 ] {b414c72b-6238-4ded-afce-9f385f54096b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Nano(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:54528) (comment: 01277_toUnixTimestamp64.sql) (in query: SELECT toUnixTimestamp64Nano();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871a62c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008717669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:56:35.498651 [ 10385 ] {b414c72b-6238-4ded-afce-9f385f54096b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Nano(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871a62c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008717669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:56:35.682129 [ 10385 ] {ce1e4ffe-38a1-412d-85dd-40fd2a747c17} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Milli'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Milli('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:54528) (comment: 01277_toUnixTimestamp64.sql) (in query: SELECT toUnixTimestamp64Milli('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e4a56c4 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:56:35.682951 [ 10385 ] {ce1e4ffe-38a1-412d-85dd-40fd2a747c17} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Milli'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Milli('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e4a56c4 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:56:35.750770 [ 10385 ] {ac0f0056-6511-4dbe-a76e-3cc88415385a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Micro'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Micro('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:54528) (comment: 01277_toUnixTimestamp64.sql) (in query: SELECT toUnixTimestamp64Micro('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e4a56c4 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:56:35.772180 [ 10385 ] {ac0f0056-6511-4dbe-a76e-3cc88415385a} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Micro'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Micro('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e4a56c4 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:56:35.792532 [ 10385 ] {ab43d2d2-0042-42f8-9de4-3f722ec77cb1} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Nano'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Nano('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:54528) (comment: 01277_toUnixTimestamp64.sql) (in query: SELECT toUnixTimestamp64Nano('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e4a56c4 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:56:35.793825 [ 10385 ] {ab43d2d2-0042-42f8-9de4-3f722ec77cb1} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'toUnixTimestamp64Nano'. Expected: DateTime64, got: String: In scope SELECT toUnixTimestamp64Nano('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::FunctionToUnixTimestamp64::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e4a56c4 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:56:35.887552 [ 10385 ] {e3fa4a18-156f-4844-a0ba-9a4e77d1a403} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Milli('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:54528) (comment: 01277_toUnixTimestamp64.sql) (in query: SELECT toUnixTimestamp64Milli('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871a62c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008717669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:56:35.889121 [ 10385 ] {e3fa4a18-156f-4844-a0ba-9a4e77d1a403} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Milli('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871a62c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008717669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:56:35.901497 [ 10385 ] {5e48fc42-4cb5-4fe3-84f5-22b05394f958} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Micro('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:54528) (comment: 01277_toUnixTimestamp64.sql) (in query: SELECT toUnixTimestamp64Micro('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871a62c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008717669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:56:35.902523 [ 10385 ] {5e48fc42-4cb5-4fe3-84f5-22b05394f958} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Micro('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871a62c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008717669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:56:35.920304 [ 10385 ] {60cc2520-4527-4241-86d7-8f1b1e43c6a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Nano('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:54528) (comment: 01277_toUnixTimestamp64.sql) (in query: SELECT toUnixTimestamp64Nano('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871a62c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008717669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:56:35.921675 [ 10385 ] {60cc2520-4527-4241-86d7-8f1b1e43c6a7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Nano('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000871a62c 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000008717669 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717d9f 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:56:39.035252 [ 10385 ] {d80055d4-8224-42c4-8488-e96e026a862c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:54612) (comment: 01681_bloom_filter_nullable_column.sql) (in query: SELECT * FROM bloom_filter_nullable_index WHERE str IN (SELECT '1048576', str FROM bloom_filter_nullable_index) SETTINGS transform_null_in = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2f303a 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::FutureSetFromSubquery::buildOrderedSetInplace(std::shared_ptr const&) @ 0x0000000017edb9c8 12. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:407: DB::MergeTreeIndexConditionBloomFilter::traverseFunction(DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&, DB::RPNBuilderTreeNode const*) @ 0x0000000019b584af 13. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:0: DB::MergeTreeIndexConditionBloomFilter::extractAtomFromTree(DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&) @ 0x0000000019b58255 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000019b5ee32 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000019b70a1a 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b56cac 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::MergeTreeIndexBloomFilter::createIndexCondition(DB::ActionsDAG const*, std::shared_ptr) const @ 0x0000000019b5e644 18. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1602: DB::buildIndexes(std::optional&, DB::ActionsDAG const*, DB::MergeTreeData const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001a949f61 19. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1639: DB::ReadFromMergeTree::applyFilters(DB::ActionDAGNodes) @ 0x000000001a948be8 20. ./src/Processors/QueryPlan/SourceStepWithFilter.h:0: DB::SourceStepWithFilter::applyFilters() @ 0x000000001aa21063 21. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:50: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000001aa20ef1 22. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001aa04552 23. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001a92223a 24. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a920d30 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dc3569 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017dc3210 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 2025.10.23 23:56:39.036015 [ 10385 ] {d80055d4-8224-42c4-8488-e96e026a862c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2f303a 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::FutureSetFromSubquery::buildOrderedSetInplace(std::shared_ptr const&) @ 0x0000000017edb9c8 12. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:407: DB::MergeTreeIndexConditionBloomFilter::traverseFunction(DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&, DB::RPNBuilderTreeNode const*) @ 0x0000000019b584af 13. ./build_docker/./src/Storages/MergeTree/MergeTreeIndexBloomFilter.cpp:0: DB::MergeTreeIndexConditionBloomFilter::extractAtomFromTree(DB::RPNBuilderTreeNode const&, DB::MergeTreeIndexConditionBloomFilter::RPNElement&) @ 0x0000000019b58255 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000019b5ee32 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000019b70a1a 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019b56cac 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::MergeTreeIndexBloomFilter::createIndexCondition(DB::ActionsDAG const*, std::shared_ptr) const @ 0x0000000019b5e644 18. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1602: DB::buildIndexes(std::optional&, DB::ActionsDAG const*, DB::MergeTreeData const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000001a949f61 19. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1639: DB::ReadFromMergeTree::applyFilters(DB::ActionDAGNodes) @ 0x000000001a948be8 20. ./src/Processors/QueryPlan/SourceStepWithFilter.h:0: DB::SourceStepWithFilter::applyFilters() @ 0x000000001aa21063 21. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:50: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000001aa20ef1 22. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:0: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000001aa04552 23. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000001a92223a 24. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:0: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a920d30 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dc3569 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017dc3210 27. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 2025.10.23 23:56:39.569194 [ 10385 ] {327a57a0-d2f2-4561-b47e-22df6b9ec292} executeQuery: Code: 57. DB::Exception: Table test_1.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50278) (comment: 02889_print_pretty_type_names.sql) (in query: create table test (a Tuple(b String, c Tuple(d Nullable(UInt64), e Array(UInt32), f Array(Tuple(g String, h Map(String, Array(Tuple(i String, j UInt64))))), k Date), l Nullable(String))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:56:39.576949 [ 10385 ] {327a57a0-d2f2-4561-b47e-22df6b9ec292} TCPHandler: Code: 57. DB::Exception: Table test_1.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:56:40.791494 [ 10931 ] {bd325f0b-2d2d-49d2-a685-44a62d075d91} executeQuery: Code: 36. DB::Exception: Tables have different primary key. (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50326) (comment: 02455_improve_feedback_when_replacing_partition_with_different_primary_key.sql) (in query: ALTER TABLE test_b REPLACE PARTITION '0' FROM test_a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7289: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000019a3b415 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7319: DB::MergeTreeData::checkStructureAndGetMergeTreeData(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000019a3b619 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x0000000019e7cfe6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000019a16c39 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c29cc9 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:56:40.792126 [ 10931 ] {bd325f0b-2d2d-49d2-a685-44a62d075d91} TCPHandler: Code: 36. DB::Exception: Tables have different primary key. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7289: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000019a3b415 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:7319: DB::MergeTreeData::checkStructureAndGetMergeTreeData(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000019a3b619 6. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x0000000019e7cfe6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000019a16c39 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c29cc9 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:56:41.449454 [ 10931 ] {b34d000a-4413-4bca-899a-6ee35e164c20} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50362) (comment: 00472_create_view_if_not_exists.sql) (in query: DROP TABLE t_00472;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1e9f1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c766aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c74615 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c739c9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:56:41.450474 [ 10931 ] {b34d000a-4413-4bca-899a-6ee35e164c20} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1e9f1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c766aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c74615 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c739c9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:56:42.886589 [ 10385 ] {546cd0a6-038e-4936-acaf-bb09096cfc58} executeQuery: Code: 57. DB::Exception: Table test_2s57mxuq.file already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50410) (comment: 02115_write_buffers_finalize.sh) (in query: CREATE TABLE file (x UInt64) ENGINE = File(Native, 'test_2s57mxuq/bz2.data.bz2')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:56:42.890410 [ 10385 ] {546cd0a6-038e-4936-acaf-bb09096cfc58} TCPHandler: Code: 57. DB::Exception: Table test_2s57mxuq.file already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:56:53.106563 [ 2813 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:56:55.287413 [ 10385 ] {46833bc8-949d-4248-a731-c12521494816} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=724). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:54638) (comment: 02421_simple_queries_for_opentelemetry.sh) (in query: SELECT attribute['db.statement'] as query FROM system.opentelemetry_span_log WHERE finish_date >= yesterday() AND operation_name = 'query' AND attribute['clickhouse.query_id'] = '2a5a1647-0109-4b6c-89fb-1c3f423b52f9' Format JSONEachRow ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:56:55.289431 [ 10385 ] {46833bc8-949d-4248-a731-c12521494816} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=724). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:57:00.693474 [ 10385 ] {75494f25-dd9d-4819-ac10-de04b208c8a9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=724). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:44238) (comment: 02421_simple_queries_for_opentelemetry.sh) (in query: select * from opentelemetry_test format Null ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:57:00.696369 [ 10385 ] {75494f25-dd9d-4819-ac10-de04b208c8a9} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=724). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:57:03.879879 [ 10385 ] {50f3af47-8615-4f65-8000-9969ecf0b81c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:44258) (comment: 02421_simple_queries_for_opentelemetry.sh) (in query: SELECT attribute['db.statement'] as query, attribute['clickhouse.read_rows'] as read_rows, attribute['clickhouse.written_rows'] as written_rows FROM system.opentelemetry_span_log WHERE finish_date >= yesterday() AND operation_name = 'query' AND attribute['clickhouse.query_id'] = '75494f25-dd9d-4819-ac10-de04b208c8a9' Format JSONEachRow ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019afcfca 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001a947c35 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a94638f 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1454: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a946030 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1934: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9507fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8f5f22 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9210b9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dc3569 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017dc3210 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:57:03.883874 [ 10385 ] {50f3af47-8615-4f65-8000-9969ecf0b81c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019afcfca 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001a947c35 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a94638f 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1454: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a946030 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1934: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9507fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8f5f22 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9210b9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dc3569 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017dc3210 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:57:07.667750 [ 10385 ] {7194712e-7ac0-4003-a629-c80fa09f493d} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:44354) (comment: 02183_dictionary_date_types.sql) (in query: DROP DICTIONARY 02183_hashed_dictionary;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c771c0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c74615 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c739c9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:57:07.669314 [ 10385 ] {7194712e-7ac0-4003-a629-c80fa09f493d} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c771c0 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c74615 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c739c9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:57:08.624732 [ 10385 ] {565c07e0-bf98-4f30-9e4c-83dbfbf97054} executeQuery: Code: 36. DB::Exception: Argument 'kafka_broker_list' must be a literal, get Function_equals (value: a = '1'). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:44376) (comment: 03305_fix_kafka_table_with_kw_arguments.sql) (in query: CREATE TABLE default.test ( `id` UInt32, `message` String ) ENGINE = Kafka(a = '1', 'clickhouse');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000007b6572c 4. ./build_docker/./src/Storages/checkAndGetLiteralArgument.cpp:0: String DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x00000000195b519e 5. ./build_docker/./src/Storages/Kafka/StorageKafkaUtils.cpp:0: DB::registerStorageKafka(DB::StorageFactory&)::$_0::operator()(DB::StorageFactory::Arguments const&) const @ 0x000000001632af1c 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001632a11b 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.23 23:57:08.625914 [ 10385 ] {565c07e0-bf98-4f30-9e4c-83dbfbf97054} TCPHandler: Code: 36. DB::Exception: Argument 'kafka_broker_list' must be a literal, get Function_equals (value: a = '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x0000000007b6572c 4. ./build_docker/./src/Storages/checkAndGetLiteralArgument.cpp:0: String DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x00000000195b519e 5. ./build_docker/./src/Storages/Kafka/StorageKafkaUtils.cpp:0: DB::registerStorageKafka(DB::StorageFactory&)::$_0::operator()(DB::StorageFactory::Arguments const&) const @ 0x000000001632af1c 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001632a11b 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.23 23:57:16.301467 [ 3317 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {31dc9f48-44c4-4df8-94b6-f5019085f4b9::202510_1_56_11}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:57:20.232476 [ 2687 ] {9a093dbf-7b40-487f-94b9-91bb918a0620} executeQuery: Code: 57. DB::Exception: Table test_1.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43070) (comment: 01763_filter_push_down_bugs.sql) (in query: CREATE TABLE t (`a` UInt8) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 200945594, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 431261019, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 14472391, merge_max_block_size = 13458, old_parts_lifetime = 297., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1534661496, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 60438, primary_key_compress_block_size = 18899), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:57:20.234410 [ 2687 ] {9a093dbf-7b40-487f-94b9-91bb918a0620} TCPHandler: Code: 57. DB::Exception: Table test_1.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:57:24.276968 [ 2687 ] {09f0e1ab-f826-4953-bbdb-e166b8b4546c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43118) (comment: 01550_create_map_type.sql) (in query: CREATE TABLE table_map (`d` DATE, `m` Map(Int8, UInt256)) ENGINE = MergeTree ORDER BY d SETTINGS index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 318519247, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 21161506, merge_max_block_size = 12912, old_parts_lifetime = 376., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 67185, primary_key_compress_block_size = 90481), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 2025.10.23 23:57:24.278044 [ 2687 ] {09f0e1ab-f826-4953-bbdb-e166b8b4546c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 2025.10.23 23:57:24.815684 [ 2687 ] {4a9bbaf5-ce18-4f95-bc1e-bcefa893fa99} executeQuery: Code: 57. DB::Exception: Table test_1.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43150) (comment: 02429_offset_pipeline_stuck_bug.sql) (in query: CREATE TABLE t ENGINE = Log AS SELECT * FROM system.numbers LIMIT 20;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:57:24.817465 [ 2687 ] {4a9bbaf5-ce18-4f95-bc1e-bcefa893fa99} TCPHandler: Code: 57. DB::Exception: Table test_1.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:57:27.163746 [ 2687 ] {a8aeaf76-7cfd-4f4b-bd45-7fb81a0a4276} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '(' at end of stream.: while converting '' to Tuple(UInt8): In scope SELECT tuple(1) < ''. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43172) (comment: 01329_compare_tuple_string_constant.sql) (in query: SELECT tuple(1) < '';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000fa9ddf6 5. ./src/IO/ReadBuffer.h:114: void DB::SerializationTuple::deserializeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000017042321 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:226: DB::SerializationTuple::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x000000001703c73a 7. DB::SimpleTextSerialization::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000000771e764 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181d0f49 9. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181ce369 10. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b97dbd7 11. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b964c9e 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 28. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 2025.10.23 23:57:27.164699 [ 2687 ] {a8aeaf76-7cfd-4f4b-bd45-7fb81a0a4276} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '(' at end of stream.: while converting '' to Tuple(UInt8): In scope SELECT tuple(1) < ''. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000fa9ddf6 5. ./src/IO/ReadBuffer.h:114: void DB::SerializationTuple::deserializeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000017042321 6. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:226: DB::SerializationTuple::deserializeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x000000001703c73a 7. DB::SimpleTextSerialization::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000000771e764 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181d0f49 9. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000181ce369 10. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b97dbd7 11. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b964c9e 12. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 13. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 28. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 2025.10.23 23:57:27.599234 [ 2687 ] {5ce058db-66bb-4314-b096-c0e64fffd5d7} executeQuery: Code: 386. DB::Exception: There is no supertype for types Tuple(UInt8), String because some of them are Tuple and some of them are not. (NO_COMMON_TYPE) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43172) (comment: 01329_compare_tuple_string_constant.sql) (in query: SELECT tuple(1) < materialize('');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000d49b246 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000016f3f460 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:402: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000016f44c65 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000b97ec42 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b965db0 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000173fcdc6 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000173fb1df 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001a6a6dea 16. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:32: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000001a8d7de7 17. ./contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x000000001623d2a2 18. ./build_docker/./src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000017dd5865 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcea57 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.23 23:57:27.600511 [ 2687 ] {5ce058db-66bb-4314-b096-c0e64fffd5d7} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Tuple(UInt8), String because some of them are Tuple and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000d49b246 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000016f3f460 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:402: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000016f44c65 6. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000b97ec42 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b965db0 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x00000000173fcdc6 14. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000173fb1df 15. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001a6a6dea 16. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:32: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000001a8d7de7 17. ./contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x000000001623d2a2 18. ./build_docker/./src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000017dd5865 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcea57 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.23 23:57:31.049106 [ 10932 ] {4bb424f8-050d-4290-91a6-857553d3e205} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47284) (in query: select last_refresh_result from refreshes -- 50), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:57:31.141609 [ 10932 ] {4bb424f8-050d-4290-91a6-857553d3e205} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=725). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:57:32.066403 [ 11324 ] {} ExternalDictionariesLoader: Could not update external dictionary '4d942a90-5124-4d50-8e84-011027e2fc87', leaving the previous version, next update is scheduled at 2025-10-23 23:57:37: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bfc297 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000019bfd21f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f57e90 13. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:0: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000170291cf 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f581e4 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019bf9bd6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bf97d5 17. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x0000000019abec34 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aba072 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c63e3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 25. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 26. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a30a201 31. ./build_docker/./src/Dictionaries/DictionaryPipelineExecutor.cpp:0: DB::DictionaryPipelineExecutor::pull(DB::Block&) @ 0x000000000ff54611 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:57:35.090474 [ 2687 ] {fcdaa20e-3b4e-4d51-b273-fd02a80900d7} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(9, 4) and Decimal(9, 4) of arguments for aggregate function covarPop. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43198) (comment: 00700_decimal_aggregates.sql) (in query: SELECT covarPop(a, a), covarPop(b, b), covarPop(c, c) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x00000000139204ec 4. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:0: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000014bda926 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001364d97e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001622fc6c 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001622daab 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2fca 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:57:35.092010 [ 2687 ] {fcdaa20e-3b4e-4d51-b273-fd02a80900d7} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(9, 4) and Decimal(9, 4) of arguments for aggregate function covarPop. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x00000000139204ec 4. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:0: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000014bda926 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001364d97e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001622fc6c 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001622daab 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2fca 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:57:35.566295 [ 2687 ] {2de63b83-54c5-47f7-9a1c-08b3bb5f53ae} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(9, 4) and Decimal(9, 4) of arguments for aggregate function covarSamp. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43198) (comment: 00700_decimal_aggregates.sql) (in query: SELECT covarSamp(a, a), covarSamp(b, b), covarSamp(c, c) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x00000000139204ec 4. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:0: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000014bda566 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001364d97e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001622fc6c 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001622daab 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2fca 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:57:35.567556 [ 2687 ] {2de63b83-54c5-47f7-9a1c-08b3bb5f53ae} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(9, 4) and Decimal(9, 4) of arguments for aggregate function covarSamp. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x00000000139204ec 4. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:0: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000014bda566 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001364d97e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001622fc6c 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001622daab 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2fca 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:57:36.229752 [ 2687 ] {c39d3b66-7396-4216-b78e-6bc0d8ddc574} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(9, 4) and Decimal(9, 4) of arguments for aggregate function corr. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43198) (comment: 00700_decimal_aggregates.sql) (in query: SELECT corr(a, a), corr(b, b), corr(c, c) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x00000000139204ec 4. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:0: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000014d2721d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001364d97e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001622fc6c 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001622daab 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2fca 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:57:36.231355 [ 2687 ] {c39d3b66-7396-4216-b78e-6bc0d8ddc574} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(9, 4) and Decimal(9, 4) of arguments for aggregate function corr. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x00000000139204ec 4. ./src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:0: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000014d2721d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001364d97e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001622fc6c 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x000000001622daab 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2fca 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.23 23:57:39.637750 [ 10932 ] {08cd6653-43a4-416f-9c99-ee4a33cabf8f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:46042) (comment: 03150_grouping_sets_use_nulls_pushdown.sql) (in query: INSERT INTO test_grouping_sets_predicate SELECT toDate('2023-01-05') AS day_, 'hello, world' FROM numbers (10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f356a 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:57:39.639160 [ 10932 ] {08cd6653-43a4-416f-9c99-ee4a33cabf8f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f356a 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:57:41.903920 [ 10932 ] {b3dda5aa-1788-49b5-8669-7e092d92a2d0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:40340) (comment: 01312_skip_empty_params.sh) (in query: select 1 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a518951 8. ./contrib/llvm-project/libcxx/include/atomic:1009: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000001a517265 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000001a519ae0 10. ./src/Processors/Formats/IOutputFormat.h:110: DB::IOutputFormat::work() @ 0x000000001a31438c 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 15. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2f303a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000182258bc 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 18. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.23 23:57:41.906369 [ 10932 ] {b3dda5aa-1788-49b5-8669-7e092d92a2d0} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): While executing ParallelFormattingOutputFormat. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a518951 8. ./contrib/llvm-project/libcxx/include/atomic:1009: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000001a517265 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::ParallelFormattingOutputFormat::writePrefix() @ 0x000000001a519ae0 10. ./src/Processors/Formats/IOutputFormat.h:110: DB::IOutputFormat::work() @ 0x000000001a31438c 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 15. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2f303a 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000182258bc 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 18. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:57:44.292813 [ 3875 ] {e4af7d86-27ae-4ca8-8042-88e8b9254bbb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=723). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:46106) (in query: select last_refresh_result from refreshes -- 50), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:57:44.294507 [ 3875 ] {e4af7d86-27ae-4ca8-8042-88e8b9254bbb} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=774, jobs=723). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:57:44.691533 [ 2687 ] {e782bebb-b46f-4905-80bb-f5156c4c9cbc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:46146) (comment: 02046_low_cardinality_parallel_group_by.sh) (in query: SELECT count() FROM low_card_buffer_test GROUP BY test_text format Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:57:44.695131 [ 2687 ] {e782bebb-b46f-4905-80bb-f5156c4c9cbc} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:57:46.613860 [ 16192 ] {7f9c8b17-94db-4054-92c8-ca3bf5024033} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=777, jobs=724). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:46178) (comment: 02046_low_cardinality_parallel_group_by.sh) (in query: INSERT INTO low_card_buffer_test values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f2d53 8. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000001a1ec1ec 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:57:46.614724 [ 16192 ] {7f9c8b17-94db-4054-92c8-ca3bf5024033} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=777, jobs=724). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f2d53 8. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000001a1ec1ec 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:57:47.331014 [ 3511 ] {} ExternalDictionariesLoader: Could not update external dictionary '4d942a90-5124-4d50-8e84-011027e2fc87', leaving the previous version, next update is scheduled at 2025-10-23 23:57:51: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): (while reading column third_column): (while reading from part /var/lib/clickhouse/store/847/8471dccc-d02b-4a9b-be32-a2c153b48d95/all_1_1_0/ in table database_for_dict.table_for_dict (8471dccc-d02b-4a9b-be32-a2c153b48d95) located on disk default of type local, from mark 0 with max_rows_to_read = 100): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d62f83 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d65385 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d655fe 16. DB::ReadBuffer::next() @ 0x0000000007b3717b 17. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000001702f769 18. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000001702df6f 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f58c32 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x0000000019bfbc4a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bfb20e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a98c8ea 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 29. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 30. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:57:49.839291 [ 3875 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x000000001682a339 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175b6066 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000175b675b 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000001a206a77 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000001a1f6dd1 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1eb38f 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:57:52.355152 [ 3875 ] {e9062fda-3182-45e0-bb48-3a24f932b700} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:40826) (comment: 01780_column_sparse_full.sql) (in query: SELECT uniqExact(u) FROM t_sparse_full WHERE s != '';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:57:52.357751 [ 3875 ] {e9062fda-3182-45e0-bb48-3a24f932b700} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:57:53.096626 [ 2709 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:57:54.099191 [ 4101 ] {415558ac-7cd2-4685-9b2c-991f26209d42} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:41982) (comment: 01244_optimize_distributed_group_by_sharding_key.sql) (in query: SELECT count() AS `count()`, `__table1`.`number` AS `number` FROM `test_1`.`data_01247` AS `__table1` GROUP BY `__table1`.`number`, 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:57:54.100848 [ 4101 ] {415558ac-7cd2-4685-9b2c-991f26209d42} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:57:54.182005 [ 3875 ] {94a6ce39-b663-4b3c-a0d2-5dd45c49e64d} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:40840) (comment: 01244_optimize_distributed_group_by_sharding_key.sql) (in query: select count(), * from dist_01247 group by number, 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000faa1a74 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a058f02 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a063254 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0c20fe 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e35bdf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e356e0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e34243 2025.10.23 23:57:54.184369 [ 3875 ] {94a6ce39-b663-4b3c-a0d2-5dd45c49e64d} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000faa1a74 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a058f02 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a063254 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0c20fe 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e35bdf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e356e0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e34243 2025.10.23 23:57:54.331140 [ 2708 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:57:54.368729 [ 3873 ] {577922be-e5bc-4f9a-860e-fa0695c198cf} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:56428). (NETWORK_ERROR) (version 24.8.14.10544.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56428) (comment: 01244_optimize_distributed_group_by_sharding_key.sql) (in query: SELECT count() AS `count()`, `__table1`.`number` AS `number` FROM `test_1`.`data_01247` AS `__table1` GROUP BY `__table1`.`number`, 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe5aed 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe7532 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a06e78e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileEvents() @ 0x000000001a2020f7 6. ./build_docker/./src/Server/TCPHandler.cpp:1170: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f9755 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 2025.10.23 23:57:54.371823 [ 3873 ] {577922be-e5bc-4f9a-860e-fa0695c198cf} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:56428). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe5aed 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe76f0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a06e78e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000001a20b607 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000001a1fabfc 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec459 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:57:54.372280 [ 3873 ] {577922be-e5bc-4f9a-860e-fa0695c198cf} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:56428). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe5aed 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe7532 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a06e78e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileEvents() @ 0x000000001a2020f7 6. ./build_docker/./src/Server/TCPHandler.cpp:1170: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f9755 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 2025.10.23 23:57:54.373216 [ 3873 ] {577922be-e5bc-4f9a-860e-fa0695c198cf} TCPHandler: Client has gone away. 2025.10.23 23:57:55.333526 [ 2704 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:57:56.417078 [ 10932 ] {fa02ccab-359c-4c26-bfa4-db40fb278163} DynamicQueryHandler: Code: 271. DB::Exception: Cannot decompress Gorilla-encoded data. File has wrong header. (CANNOT_DECOMPRESS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Compression/CompressionCodecGorilla.cpp:429: DB::CompressionCodecGorilla::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x0000000016db6e32 5. ./build_docker/./src/Compression/ICompressionCodec.cpp:110: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x0000000016dc8710 6. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:318: DB::CompressedReadBufferBase::decompress(DB::BufferBase::Buffer&, unsigned long, unsigned long) @ 0x0000000016d6490d 7. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:13: non-virtual thunk to DB::CompressedReadBuffer::nextImpl() @ 0x0000000016d62836 8. DB::ReadBuffer::next() @ 0x0000000007b3717b 9. ./build_docker/./src/IO/ReadBuffer.cpp:0: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000001659579b 10. DB::ReadBuffer::next() @ 0x0000000007b3717b 11. ./src/IO/ConcatReadBuffer.h:0: DB::ConcatReadBuffer::nextImpl() @ 0x0000000017567677 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./src/IO/ReadBuffer.h:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224a08 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 15. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:57:57.338748 [ 2701 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:57:58.085018 [ 3024 ] {} RefreshTask: Refresh view test_13.e failed (attempt 1/1): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 15. ./src/Interpreters/InterpreterCreateQuery.h:29: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x0000000017c5085a 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1535: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4da81 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 18. ./build_docker/./src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x00000000192bab92 19. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:380: DB::RefreshTask::executeRefreshUnlocked(bool) @ 0x0000000019ff6028 20. ./contrib/llvm-project/libcxx/include/__mutex_base:207: DB::RefreshTask::refreshTask() @ 0x0000000019ff46e8 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019ff7522 22. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 24. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:57:58.341344 [ 2698 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:57:59.343488 [ 2699 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:58:04.415776 [ 2703 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:58:05.418310 [ 2701 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:58:09.426545 [ 2707 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:58:11.454766 [ 2704 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:58:19.473415 [ 2704 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:58:23.716322 [ 3875 ] {05bbdd81-65a2-4cfc-8695-32f8bd8432f8} executeQuery: Code: 36. DB::Exception: Floating point partition key is not supported: a. (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:48304) (comment: 01630_disallow_floating_point_as_partition_key.sql) (in query: CREATE TABLE test (`a` Float32, `b` int) ENGINE = MergeTree PARTITION BY a ORDER BY tuple() SETTINGS index_granularity = 16261, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 55, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 175788901, compact_parts_max_granules_to_buffer = 155, compact_parts_merge_max_bytes_to_prefetch_part = 25197988, merge_max_block_size = 8735, old_parts_lifetime = 232., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 4022152254, index_granularity_bytes = 23760539, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 94553, primary_key_compress_block_size = 10262), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:829: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a864 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 6. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:58:23.717714 [ 3875 ] {05bbdd81-65a2-4cfc-8695-32f8bd8432f8} TCPHandler: Code: 36. DB::Exception: Floating point partition key is not supported: a. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:829: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a864 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 6. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:58:23.961979 [ 3875 ] {8ef2a5d5-f123-4b05-8a2a-10b4e32cb57e} executeQuery: Code: 57. DB::Exception: Table test_1.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:48304) (comment: 01630_disallow_floating_point_as_partition_key.sql) (in query: CREATE TABLE test (`a` Float32, `b` int, `c` String, `d` Float64) ENGINE = MergeTree PARTITION BY (b, c, d) ORDER BY tuple() SETTINGS allow_floating_point_partition_key = false, index_granularity = 16261, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 55, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 175788901, compact_parts_max_granules_to_buffer = 155, compact_parts_merge_max_bytes_to_prefetch_part = 25197988, merge_max_block_size = 8735, old_parts_lifetime = 232., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 4022152254, index_granularity_bytes = 23760539, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 94553, primary_key_compress_block_size = 10262), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:58:23.963366 [ 3875 ] {8ef2a5d5-f123-4b05-8a2a-10b4e32cb57e} TCPHandler: Code: 57. DB::Exception: Table test_1.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:58:24.488802 [ 2711 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:58:25.492956 [ 2707 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:58:27.231887 [ 11322 ] {} ExternalDictionariesLoader: Could not update external dictionary '36ef1abc-abab-4f85-93c6-36b673161500', leaving the previous version, next update is scheduled at 2025-10-23 23:58:32: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019afcfca 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001a947c35 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a94638f 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1454: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a946030 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1934: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9507fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8f5f22 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9210b9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dc3569 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017dc3210 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000000fe64c6e 19. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:115: DB::ClickHouseDictionarySource::loadAll() @ 0x000000000fe64b68 20. DB::FlatDictionary::loadData() @ 0x000000000ff59b00 21. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000ff592e0 22. std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration const&, std::shared_ptr const&, void>(std::allocator const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::FlatDictionary::Configuration const&, std::shared_ptr const&) @ 0x000000000ff8e02b 23. DB::FlatDictionary::clone() const @ 0x000000000ff81967 24. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1519: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x0000000017be631f 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000017be1eb1 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000017bea528 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000017bea322 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 30. __tsan_thread_start_func @ 0x000000000758df2f 31. ? @ 0x00007f7c69445ac3 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:58:27.590487 [ 3509 ] {} ExternalDictionariesLoader: Could not update external dictionary '4d942a90-5124-4d50-8e84-011027e2fc87', leaving the previous version, next update is scheduled at 2025-10-23 23:58:33: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): (while reading column second_column): (while reading from part /var/lib/clickhouse/store/847/8471dccc-d02b-4a9b-be32-a2c153b48d95/all_1_1_0/ in table database_for_dict.table_for_dict (8471dccc-d02b-4a9b-be32-a2c153b48d95) located on disk default of type local, from mark 0 with max_rows_to_read = 100): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000016d64235 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d65c54 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d661ce 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fe0f1e 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f58c32 18. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:0: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000001702b604 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x0000000019bfbc4a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bfb20e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a98c8ea 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 28. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 29. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:58:28.501019 [ 2703 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:58:30.505883 [ 2698 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:58:32.510188 [ 2711 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:58:34.514221 [ 2708 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:58:37.520025 [ 2701 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:58:38.854473 [ 2698 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1dfa7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:58:41.017578 [ 2795 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:58:43.032753 [ 10931 ] {70d6b45e-b8d5-4282-9e2f-f1fd46c89b5d} executeQuery: Code: 410. DB::Exception: BridgeHelper: clickhouse-odbc-bridge is not responding. (EXTERNAL_SERVER_IS_NOT_RESPONDING) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50498) (comment: 01086_odbc_roundtrip.sh) (in query: select count() > 1 as ok from (select * from odbc('DSN={ClickHouse DSN (ANSI)}','system','tables'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/BridgeHelper/IBridgeHelper.cpp:0: DB::IBridgeHelper::startBridgeSync() @ 0x000000001a0d9a59 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::ITableFunctionXDBC::startBridgeIfNot(std::shared_ptr) const @ 0x0000000015ea5d74 6. ./build_docker/./src/TableFunctions/ITableFunctionXDBC.cpp:0: DB::(anonymous namespace)::ITableFunctionXDBC::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015ea567d 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 8. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1bbd 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d690b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.23 23:58:43.034713 [ 10931 ] {70d6b45e-b8d5-4282-9e2f-f1fd46c89b5d} TCPHandler: Code: 410. DB::Exception: BridgeHelper: clickhouse-odbc-bridge is not responding. (EXTERNAL_SERVER_IS_NOT_RESPONDING), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/BridgeHelper/IBridgeHelper.cpp:0: DB::IBridgeHelper::startBridgeSync() @ 0x000000001a0d9a59 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::ITableFunctionXDBC::startBridgeIfNot(std::shared_ptr) const @ 0x0000000015ea5d74 6. ./build_docker/./src/TableFunctions/ITableFunctionXDBC.cpp:0: DB::(anonymous namespace)::ITableFunctionXDBC::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015ea567d 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 8. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1bbd 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d690b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.23 23:58:44.568950 [ 10929 ] {55a7fa29-cb90-4028-ab14-84509b9cfc83} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=777, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53204) (in query: select last_refresh_result from refreshes -- 50), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:58:44.581562 [ 10929 ] {55a7fa29-cb90-4028-ab14-84509b9cfc83} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=777, jobs=725). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:58:46.924475 [ 2698 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:58:47.516442 [ 3149 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:58:49.933248 [ 2707 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:58:52.134890 [ 10929 ] {43b9f384-e425-4655-b834-85a103264a3f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=777, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:39964) (in query: select last_refresh_result from refreshes -- 50), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:58:52.137882 [ 10929 ] {43b9f384-e425-4655-b834-85a103264a3f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=777, jobs=725). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:58:53.921237 [ 10385 ] {0c9d306b-a8a7-46c8-814f-93291c2b09f0} executeQuery: Code: 302. DB::Exception: Child process was exited with return code 88. (CHILD_WAS_NOT_EXITED_NORMALLY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53200) (comment: 01086_odbc_roundtrip.sh) (in query: select count() > 1 as ok from (select * from odbc('DSN={ClickHouse DSN (ANSI)}','system','tables'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Common/ShellCommand.cpp:0: DB::ShellCommand::handleProcessRetcode(int) const @ 0x000000000fc36cc8 5. ./build_docker/./src/Common/ShellCommand.cpp:396: DB::ShellCommand::waitIfProccesTerminated() @ 0x000000000fc36d91 6. ./build_docker/./src/Common/ShellCommandsHolder.cpp:25: DB::ShellCommandsHolder::addCommand(std::unique_ptr>) @ 0x000000000fe05d19 7. ./src/BridgeHelper/XDBCBridgeHelper.h:148: DB::XDBCBridgeHelper::startBridge(std::unique_ptr>) const @ 0x000000000fea00c8 8. ./build_docker/./src/BridgeHelper/IBridgeHelper.cpp:0: DB::IBridgeHelper::startBridgeSync() @ 0x000000001a0d92bd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::ITableFunctionXDBC::startBridgeIfNot(std::shared_ptr) const @ 0x0000000015ea5d74 10. ./build_docker/./src/TableFunctions/ITableFunctionXDBC.cpp:0: DB::(anonymous namespace)::ITableFunctionXDBC::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015ea567d 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 12. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1bbd 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d690b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 2025.10.23 23:58:53.924351 [ 10385 ] {0c9d306b-a8a7-46c8-814f-93291c2b09f0} TCPHandler: Code: 302. DB::Exception: Child process was exited with return code 88. (CHILD_WAS_NOT_EXITED_NORMALLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Common/ShellCommand.cpp:0: DB::ShellCommand::handleProcessRetcode(int) const @ 0x000000000fc36cc8 5. ./build_docker/./src/Common/ShellCommand.cpp:396: DB::ShellCommand::waitIfProccesTerminated() @ 0x000000000fc36d91 6. ./build_docker/./src/Common/ShellCommandsHolder.cpp:25: DB::ShellCommandsHolder::addCommand(std::unique_ptr>) @ 0x000000000fe05d19 7. ./src/BridgeHelper/XDBCBridgeHelper.h:148: DB::XDBCBridgeHelper::startBridge(std::unique_ptr>) const @ 0x000000000fea00c8 8. ./build_docker/./src/BridgeHelper/IBridgeHelper.cpp:0: DB::IBridgeHelper::startBridgeSync() @ 0x000000001a0d92bd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::ITableFunctionXDBC::startBridgeIfNot(std::shared_ptr) const @ 0x0000000015ea5d74 10. ./build_docker/./src/TableFunctions/ITableFunctionXDBC.cpp:0: DB::(anonymous namespace)::ITableFunctionXDBC::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015ea567d 11. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 12. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1bbd 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d690b 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 2025.10.23 23:58:54.946114 [ 2698 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:58:55.961531 [ 3875 ] {637ae408-bcdc-42d3-8c33-8be105f84a04} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:40030) (in query: SELECT DISTINCT arrayJoin(extractAll(name, '[\\w_]{2,}')) AS res FROM (SELECT * FROM viewIfPermitted(SELECT name FROM system.functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_engines ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.formats ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.data_type_families ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.merge_tree_settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT keyword FROM system.keywords ELSE null('keyword String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT cluster FROM system.clusters ELSE null('cluster String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT macro FROM system.macros ELSE null('macro String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT policy_name FROM system.storage_policies ELSE null('policy_name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT concat(func.name, comb.name) AS x FROM system.functions AS func CROSS JOIN system.aggregate_function_combinators AS comb WHERE is_aggregate ELSE null('x String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.databases LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.tables LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.dictionaries LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.columns LIMIT 10000 ELSE null('name String'))) WHERE notEmpty(res)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:58:55.996254 [ 3875 ] {637ae408-bcdc-42d3-8c33-8be105f84a04} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:58:55.997167 [ 3875 ] {637ae408-bcdc-42d3-8c33-8be105f84a04} TCPHandler: Client has gone away. 2025.10.23 23:58:58.967232 [ 2708 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:58:59.969080 [ 2704 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:59:00.971650 [ 2703 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:59:01.973883 [ 2701 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:59:02.285011 [ 3309 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {678af7ec-371a-476f-b893-c6848743a362::202510_1_80_16}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:59:05.022830 [ 2757 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:59:06.288524 [ 3312 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3391eeb9-30c2-4727-900d-ef688a8fcf48::202510_1_92_19}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:59:06.783024 [ 10385 ] {7239e2c8-69ba-4caf-843a-118b34648cf7} DB::ConcurrentHashJoin::ConcurrentHashJoin(ContextPtr, std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017737538 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000017e1b9ba 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017df9710 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de9fd2 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcad8b 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 23. __tsan_thread_start_func @ 0x000000000758df2f 24. ? @ 0x00007f7c69445ac3 25. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:59:06.787798 [ 10385 ] {7239e2c8-69ba-4caf-843a-118b34648cf7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44936) (comment: 03231_pr_duplicate_announcement_2.sql) (in query: SELECT 'CAT' AS `b`, `__table3`.`ANIMAL` AS `c` FROM `test_1`.`ANIMAL` AS `__table1` ALL INNER JOIN `test_1`.`ANIMAL` AS `__table2` ON `__table1`.`ANIMAL` = `__table2`.`ANIMAL` ALL LEFT JOIN `test_1`.`ANIMAL` AS `__table3` ON `__table2`.`ANIMAL` = `__table3`.`ANIMAL` ALL RIGHT JOIN ((SELECT `__table6`.`ANIMAL` AS `ANIMAL` FROM `test_1`.`ANIMAL` AS `__table6`) UNION ALL (SELECT `__table8`.`ANIMAL` AS `ANIMAL` FROM `test_1`.`ANIMAL` AS `__table8`) UNION ALL (SELECT `__table10`.`ANIMAL` AS `ANIMAL` FROM `test_1`.`ANIMAL` AS `__table10`)) AS `__table4` ON `__table1`.`ANIMAL` = `__table4`.`ANIMAL` WHERE (`__table4`.`ANIMAL` != 'CAT') AND (`__table3`.`ANIMAL` != 'DOG') AND (`__table2`.`ANIMAL` != 'FISH')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017737538 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000017e1b9ba 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017df9710 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de9fd2 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcad8b 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 23. __tsan_thread_start_func @ 0x000000000758df2f 24. ? @ 0x00007f7c69445ac3 25. ? @ 0x00007f7c694d7850 2025.10.23 23:59:06.789977 [ 10385 ] {7239e2c8-69ba-4caf-843a-118b34648cf7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017737538 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000017e1b9ba 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017df9710 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de9fd2 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcad8b 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 23. __tsan_thread_start_func @ 0x000000000758df2f 24. ? @ 0x00007f7c69445ac3 25. ? @ 0x00007f7c694d7850 2025.10.23 23:59:06.951030 [ 10931 ] {352ec700-6767-4d43-81c1-0640e7575ee9} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017737538 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000017e1b9ba 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017df9710 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de9fd2 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcad8b 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 23. __tsan_thread_start_func @ 0x000000000758df2f 24. ? @ 0x00007f7c69445ac3 25. ? @ 0x00007f7c694d7850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:42452) (comment: 03231_pr_duplicate_announcement_2.sql) (in query: SELECT * FROM ( SELECT x.b AS x, countDistinct(x.c) AS ANIMAL FROM ( SELECT a.ANIMAL AS a, 'CAT' AS b, c.ANIMAL AS c, d.ANIMAL AS d FROM ANIMAL AS a INNER JOIN ANIMAL AS b ON a.ANIMAL = b.ANIMAL LEFT JOIN ANIMAL AS c ON b.ANIMAL = c.ANIMAL RIGHT JOIN ( SELECT * FROM ANIMAL UNION ALL SELECT * FROM ANIMAL UNION ALL SELECT * FROM ANIMAL ) AS d ON a.ANIMAL = d.ANIMAL WHERE (d.ANIMAL != 'CAT') AND (c.ANIMAL != 'DOG') AND (b.ANIMAL != 'FISH') ) AS x WHERE x.b >= 'CAT' GROUP BY x.b HAVING ANIMAL >= 0 ) AS ANIMAL WHERE ANIMAL.ANIMAL >= 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000faa1a74 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a058f02 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a063254 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000001a0bcbd7 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000016e36cdb 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e35bdf 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e356e0 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e34243 2025.10.23 23:59:07.074362 [ 10931 ] {352ec700-6767-4d43-81c1-0640e7575ee9} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017737538 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000017e1b9ba 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017df9710 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de9fd2 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcad8b 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 23. __tsan_thread_start_func @ 0x000000000758df2f 24. ? @ 0x00007f7c69445ac3 25. ? @ 0x00007f7c694d7850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000faa1a74 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a058f02 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a063254 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:0: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000001a0bcbd7 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:50: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000016e36cdb 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e35bdf 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e356e0 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e34243 2025.10.23 23:59:07.347861 [ 3316 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {34e0b00e-fe5a-47d8-af0c-3ae1d30a34d1::202510_1_126_25}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:59:08.746498 [ 10931 ] {737cf49a-e7b0-4052-9020-e081ba4dc87d} executeQuery: Code: 223. DB::Exception: All elements of Enum data type must be of form: 'name' = number or 'name', where name is string literal and number is an integer. (UNEXPECTED_AST_STRUCTURE) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:42484) (comment: 00757_enum_defaults.sql) (in query: CREATE TABLE auto_assign_enum2 (`x` enum('a' = -1000, 'b', 'c' = -99)) ENGINE = MergeTree ORDER BY x SETTINGS index_granularity = 146, min_bytes_for_wide_part = 744042464, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 421213770, compact_parts_max_bytes_to_buffer = 394111719, compact_parts_max_granules_to_buffer = 101, compact_parts_merge_max_bytes_to_prefetch_part = 18123859, merge_max_block_size = 6827, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 731638401, index_granularity_bytes = 27480851, concurrent_part_removal_threshold = 87, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 41261, primary_key_compress_block_size = 98097), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/DataTypes/DataTypeEnum.cpp:236: DB::autoAssignNumberForEnum(std::shared_ptr const&) @ 0x0000000016e5035e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::create(std::shared_ptr const&) @ 0x0000000016e4f690 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000016e3f8c4 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000016e5a0e7 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:74: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x0000000016e57761 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:558: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000017c3f6ba 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c427d6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4d006 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 2025.10.23 23:59:08.748184 [ 10931 ] {737cf49a-e7b0-4052-9020-e081ba4dc87d} TCPHandler: Code: 223. DB::Exception: All elements of Enum data type must be of form: 'name' = number or 'name', where name is string literal and number is an integer. (UNEXPECTED_AST_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/DataTypes/DataTypeEnum.cpp:236: DB::autoAssignNumberForEnum(std::shared_ptr const&) @ 0x0000000016e5035e 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::create(std::shared_ptr const&) @ 0x0000000016e4f690 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000016e3f8c4 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000016e5a0e7 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:74: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x0000000016e57761 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:558: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000017c3f6ba 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c427d6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4d006 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 2025.10.23 23:59:09.327818 [ 10931 ] {7407109a-9afd-4874-8617-caaf8ae0b91c} executeQuery: Code: 223. DB::Exception: Elements of Enum data type must be of form: 'name' = number or 'name', where name is string literal and number is an integer. (UNEXPECTED_AST_STRUCTURE) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:42484) (comment: 00757_enum_defaults.sql) (in query: CREATE TABLE auto_assign_enum3 (`x` enum('a', 'b', NULL)) ENGINE = MergeTree ORDER BY x SETTINGS index_granularity = 146, min_bytes_for_wide_part = 744042464, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 421213770, compact_parts_max_bytes_to_buffer = 394111719, compact_parts_max_granules_to_buffer = 101, compact_parts_merge_max_bytes_to_prefetch_part = 18123859, merge_max_block_size = 6827, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 731638401, index_granularity_bytes = 27480851, concurrent_part_removal_threshold = 87, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 41261, primary_key_compress_block_size = 98097), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/DataTypes/DataTypeEnum.cpp:268: std::shared_ptr DB::createExact>(DB::IDataType const&) @ 0x0000000016e4ed14 5. ./build_docker/./src/DataTypes/DataTypeEnum.cpp:0: DB::create(std::shared_ptr const&) @ 0x0000000016e4f860 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000016e3f8c4 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000016e5a0e7 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:74: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x0000000016e57761 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:558: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000017c3f6ba 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c427d6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4d006 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 2025.10.23 23:59:09.329355 [ 10931 ] {7407109a-9afd-4874-8617-caaf8ae0b91c} TCPHandler: Code: 223. DB::Exception: Elements of Enum data type must be of form: 'name' = number or 'name', where name is string literal and number is an integer. (UNEXPECTED_AST_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/DataTypes/DataTypeEnum.cpp:268: std::shared_ptr DB::createExact>(DB::IDataType const&) @ 0x0000000016e4ed14 5. ./build_docker/./src/DataTypes/DataTypeEnum.cpp:0: DB::create(std::shared_ptr const&) @ 0x0000000016e4f860 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000016e3f8c4 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000016e5a0e7 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:74: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x0000000016e57761 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:558: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000017c3f6ba 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c427d6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4d006 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 2025.10.23 23:59:11.074407 [ 2698 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:59:12.195017 [ 10931 ] {1722ab9a-f5a4-40e2-ad9c-4acd541ac14a} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 168.00 B (attempt to allocate chunk of 0 bytes), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47568) (comment: 01062_alter_on_mutataion_zookeeper_long.sql) (in query: SELECT sum(value) from test_alter_on_mutation;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000000fa3705c 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa361e0 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa35c1e 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:85: CurrentMemoryTracker::check() @ 0x000000000f9c34a8 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1710: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x00000000177410c3 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1497: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000001774dee5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1380: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000001774d01d 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::initGenerate() @ 0x000000001a66e20c 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:646: DB::AggregatingTransform::work() @ 0x000000001a66dc98 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.23 23:59:12.196824 [ 10931 ] {1722ab9a-f5a4-40e2-ad9c-4acd541ac14a} TCPHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 168.00 B (attempt to allocate chunk of 0 bytes), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000000fa3705c 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa361e0 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa35c1e 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:85: CurrentMemoryTracker::check() @ 0x000000000f9c34a8 7. ./build_docker/./src/Interpreters/Aggregator.cpp:1710: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x00000000177410c3 8. ./build_docker/./src/Interpreters/Aggregator.cpp:1497: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000001774dee5 9. ./build_docker/./src/Interpreters/Aggregator.cpp:1380: DB::Aggregator::executeOnBlock(DB::Block const&, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x000000001774d01d 10. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::initGenerate() @ 0x000000001a66e20c 11. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:646: DB::AggregatingTransform::work() @ 0x000000001a66dc98 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.23 23:59:12.954672 [ 10385 ] {fba16e2f-cc7b-4dd9-bb4e-42f3f1d64a04} executeQuery: Code: 43. DB::Exception: Argument 'max_width' must not be NaN: In scope SELECT bar((greatCircleAngle(65537, 2, 1, 1) - 1) * 65535, 1048576, 1048577, nan). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47622) (comment: 01621_bar_nan_arguments.sql) (in query: SELECT bar((greatCircleAngle(65537, 2, 1, 1) - 1) * 65535, 1048576, 1048577, nan);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. DB::(anonymous namespace)::FunctionBar::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008948a0f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.23 23:59:12.955763 [ 10385 ] {fba16e2f-cc7b-4dd9-bb4e-42f3f1d64a04} TCPHandler: Code: 43. DB::Exception: Argument 'max_width' must not be NaN: In scope SELECT bar((greatCircleAngle(65537, 2, 1, 1) - 1) * 65535, 1048576, 1048577, nan). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. DB::(anonymous namespace)::FunctionBar::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008948a0f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.23 23:59:12.963736 [ 10385 ] {17fd249c-8faa-4893-a5e7-c74fb8ee06fd} executeQuery: Code: 43. DB::Exception: Argument 'max_width' must not be NaN: In scope SELECT bar(1, 1, 1, nan). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47622) (comment: 01621_bar_nan_arguments.sql) (in query: select bar(1,1,1,nan);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. DB::(anonymous namespace)::FunctionBar::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008948a0f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.23 23:59:12.964232 [ 10385 ] {17fd249c-8faa-4893-a5e7-c74fb8ee06fd} TCPHandler: Code: 43. DB::Exception: Argument 'max_width' must not be NaN: In scope SELECT bar(1, 1, 1, nan). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. DB::(anonymous namespace)::FunctionBar::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000008948a0f 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.23 23:59:13.079852 [ 2711 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:59:17.088954 [ 2703 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:59:18.544240 [ 18288 ] {70dc14ab-c692-4c0b-9b20-bd7ac34727e1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47702) (comment: 02416_input_json_formats.sql) (in query: select * from file(02416_data.json);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:59:18.546382 [ 18288 ] {70dc14ab-c692-4c0b-9b20-bd7ac34727e1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.23 23:59:19.109196 [ 2698 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:59:20.706607 [ 18288 ] {284e2547-3717-43ac-aca4-917607d4cd27} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'A' in scope SELECT A, toString(B) AS B_str, toString(SUM(C)) AS c_str FROM decimal GROUP BY A, B_str. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:33028) (comment: 00737_decimal_group_by.sql) (in query: SELECT A, toString(B) AS B_str, toString(SUM(C)) AS c_str FROM decimal GROUP BY A, B_str;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:59:20.708899 [ 18288 ] {284e2547-3717-43ac-aca4-917607d4cd27} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'A' in scope SELECT A, toString(B) AS B_str, toString(SUM(C)) AS c_str FROM decimal GROUP BY A, B_str. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.23 23:59:22.255334 [ 18288 ] {ab960d90-6432-4f47-a579-ff1eff1899d7} executeQuery: Code: 472. DB::Exception: Setting 'index_granularity' is readonly for storage 'ReplicatedMergeTree'. (READONLY_SETTING) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:33040) (comment: 00980_zookeeper_merge_tree_alter_settings.sql) (in query: ALTER TABLE replicated_table_for_alter1 MODIFY SETTING index_granularity = 4096;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199ecdf8 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c296fb 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:59:22.256405 [ 18288 ] {ab960d90-6432-4f47-a579-ff1eff1899d7} TCPHandler: Code: 472. DB::Exception: Setting 'index_granularity' is readonly for storage 'ReplicatedMergeTree'. (READONLY_SETTING), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000199ecdf8 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c296fb 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.23 23:59:23.658309 [ 18288 ] {ad18c9e0-4c59-412e-ad5f-6ec91cea2d16} executeQuery: Code: 252. DB::Exception: Too many parts (2 with average size of 327.00 B) in table 'test_1.replicated_table_for_alter2 (a8f25681-963e-457f-b4bd-7aaf0a140624)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:33040) (comment: 00980_zookeeper_merge_tree_alter_settings.sql) (in query: INSERT INTO replicated_table_for_alter2 VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000019a68cec 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000019a09f99 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1179: DB::ReplicatedMergeTreeSinkImpl::onStart() @ 0x0000000019df81c0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001a6a66ee 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6a6578 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a6a5d59 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x000000001a30e2a2 13. ./contrib/llvm-project/libcxx/include/vector:547: DB::TCPHandler::processInsertQuery() @ 0x000000001a1f83b0 14. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1ec09e 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.23 23:59:23.659551 [ 18288 ] {ad18c9e0-4c59-412e-ad5f-6ec91cea2d16} TCPHandler: Code: 252. DB::Exception: Too many parts (2 with average size of 327.00 B) in table 'test_1.replicated_table_for_alter2 (a8f25681-963e-457f-b4bd-7aaf0a140624)'. Merges are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&, ReadableSize&&, String&&) @ 0x0000000019a68cec 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x0000000019a09f99 5. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1179: DB::ReplicatedMergeTreeSinkImpl::onStart() @ 0x0000000019df81c0 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001a6a66ee 7. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6a6578 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a6a5d59 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 12. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:93: DB::PushingPipelineExecutor::start() @ 0x000000001a30e2a2 13. ./contrib/llvm-project/libcxx/include/vector:547: DB::TCPHandler::processInsertQuery() @ 0x000000001a1f83b0 14. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1ec09e 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.23 23:59:24.138080 [ 2704 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:59:25.494974 [ 18288 ] {5cf4d434-38b7-411e-8f6a-2534f3b3319b} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 1.00 MiB (attempt to allocate chunk of 1048639 bytes), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:33040) (comment: 00980_zookeeper_merge_tree_alter_settings.sql) (in query: CREATE TABLE replicated_table_for_reset_setting2 ( id UInt64, Data String ) ENGINE = ReplicatedMergeTree('/clickhouse/tables/test_00980_{database}/replicated_table_for_reset_setting', '2') ORDER BY id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000000fa3705c 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa361e0 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa35c1e 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:0: CurrentMemoryTracker::alloc(long) @ 0x000000000f9c356f 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000f9c0f7a 8. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000000fa99746 9. ./src/IO/BufferWithOwnMemory.h:0: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000000fac8a9b 10. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:0: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String) @ 0x000000000fac7b0f 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long) @ 0x000000000fc306b0 12. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007] const&>(std::__fs::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&) @ 0x00000000172b0766 13. ./build_docker/./src/Disks/DiskLocal.cpp:341: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x00000000172a6d2d 14. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::initializeDirectoriesAndFormatVersion(String const&, bool, String const&, bool) @ 0x00000000199a6c3e 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:343: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x000000001933f967 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000019e4f587 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a2e3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 19. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:59:25.496324 [ 18288 ] {5cf4d434-38b7-411e-8f6a-2534f3b3319b} TCPHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 1.00 MiB (attempt to allocate chunk of 1048639 bytes), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000000fa3705c 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa361e0 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa35c1e 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:0: CurrentMemoryTracker::alloc(long) @ 0x000000000f9c356f 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000f9c0f7a 8. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000000fa99746 9. ./src/IO/BufferWithOwnMemory.h:0: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000000fac8a9b 10. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:0: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String) @ 0x000000000fac7b0f 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long) @ 0x000000000fc306b0 12. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007] const&>(std::__fs::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&) @ 0x00000000172b0766 13. ./build_docker/./src/Disks/DiskLocal.cpp:341: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x00000000172a6d2d 14. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::initializeDirectoriesAndFormatVersion(String const&, bool, String const&, bool) @ 0x00000000199a6c3e 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:343: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x000000001933f967 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000019e4f587 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a2e3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 19. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.23 23:59:27.356665 [ 11323 ] {} ExternalDictionariesLoader: Could not update external dictionary '4d942a90-5124-4d50-8e84-011027e2fc87', leaving the previous version, next update is scheduled at 2025-10-23 23:59:32: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): (while reading column fourth_column): (while reading from part /var/lib/clickhouse/store/847/8471dccc-d02b-4a9b-be32-a2c153b48d95/all_1_1_0/ in table database_for_dict.table_for_dict (8471dccc-d02b-4a9b-be32-a2c153b48d95) located on disk default of type local, from mark 0 with max_rows_to_read = 100): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000016d64235 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d65c54 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d661ce 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016ff348b 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f58c32 18. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:0: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000001702b604 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x0000000019bfbc4a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bfb20e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a98c8ea 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 28. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 29. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:59:31.154168 [ 2708 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:59:33.158064 [ 2702 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:59:33.537863 [ 18288 ] {65f5e7e7-3c0e-4d8d-8599-9cbd66a180b8} executeQuery: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: while executing 'FUNCTION arrayReduce('aggThrow(0.0001)'_String :: 1, range(modulo(__table1.number, 10_UInt8)) :: 2) -> arrayReduce('aggThrow(0.0001)'_String, range(modulo(__table1.number, 10_UInt8))) UInt8 : 0'. (AGGREGATE_FUNCTION_THROW) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:58894) (comment: 01052_array_reduce_exception.sql) (in query: SELECT arrayReduce('aggThrow(0.0001)', range(number % 10)) FROM system.numbers FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAggThrow.cpp:0: DB::(anonymous namespace)::AggregateFunctionThrow::create(char*) const @ 0x0000000015b06b27 5. DB::FunctionArrayReduce::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f40cfc2 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087152b7 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.23 23:59:33.538497 [ 18288 ] {65f5e7e7-3c0e-4d8d-8599-9cbd66a180b8} TCPHandler: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: while executing 'FUNCTION arrayReduce('aggThrow(0.0001)'_String :: 1, range(modulo(__table1.number, 10_UInt8)) :: 2) -> arrayReduce('aggThrow(0.0001)'_String, range(modulo(__table1.number, 10_UInt8))) UInt8 : 0'. (AGGREGATE_FUNCTION_THROW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionAggThrow.cpp:0: DB::(anonymous namespace)::AggregateFunctionThrow::create(char*) const @ 0x0000000015b06b27 5. DB::FunctionArrayReduce::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f40cfc2 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087152b7 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.23 23:59:35.924912 [ 10931 ] {76dcaa34-c7f5-42cc-8760-b92cb437203e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:58948) (comment: 02980_s3_plain_DROP_TABLE_MergeTree.sh) (in query: select 'data after INSERT', count() from data;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f5511 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:59:35.926659 [ 10931 ] {76dcaa34-c7f5-42cc-8760-b92cb437203e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f5511 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:59:36.166386 [ 2696 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:59:36.793338 [ 10931 ] {20cbfac3-f73b-458f-af0a-43ff32782703} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE data; to attach existing table or CREATE TABLE data
; to create new table or ATTACH TABLE data FROM '/path/to/data/'
; to create new table and attach data. 2025.10.23 23:59:38.617576 [ 10931 ] {51be169f-f681-497a-bd75-8ade5a15a8e1} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to static storage. (TABLE_IS_READ_ONLY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:58976) (comment: 02980_s3_plain_DROP_TABLE_MergeTree.sh) (in query: insert into data values ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:2660: DB::StorageMergeTree::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000019e546e6 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a79ae1d 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000017d48f54 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d49eb8 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:678: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4d52f 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f7bc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:59:38.618743 [ 10931 ] {51be169f-f681-497a-bd75-8ade5a15a8e1} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to static storage. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:2660: DB::StorageMergeTree::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000019e546e6 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a79ae1d 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000017d48f54 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d49eb8 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:678: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4d52f 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f7bc 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.23 23:59:39.435911 [ 10931 ] {f719c9a2-b7e3-4712-820c-cc0757a3bc91} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to static storage. (TABLE_IS_READ_ONLY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:58976) (comment: 02980_s3_plain_DROP_TABLE_MergeTree.sh) (in query: optimize table data final;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:2660: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000019e6af10 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000018286d18 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:59:39.437411 [ 10931 ] {f719c9a2-b7e3-4712-820c-cc0757a3bc91} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to static storage. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:2660: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000019e6af10 5. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000018286d18 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.23 23:59:39.751527 [ 18288 ] {da7e5fc9-620b-4510-85ea-6ae764fd7371} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=777, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:46046) (comment: 02980_s3_plain_DROP_TABLE_MergeTree.sh) (in query: SELECT replace(data_paths[1], 's3_plain', '') FROM system.tables WHERE database = 'ordinary_test_1' AND table = 'data'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:59:39.752408 [ 18288 ] {da7e5fc9-620b-4510-85ea-6ae764fd7371} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=777, jobs=725). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.23 23:59:45.431417 [ 18288 ] {7b1fa7c8-db67-4a08-b6b3-1e6dfe475b54} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:46120) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:45.433736 [ 18288 ] {7b1fa7c8-db67-4a08-b6b3-1e6dfe475b54} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:45.985727 [ 18288 ] {ee130cae-8664-4474-9f81-46e95a394a83} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:46142) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:45.987631 [ 18288 ] {ee130cae-8664-4474-9f81-46e95a394a83} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:46.531796 [ 18288 ] {9e99b9d7-0abf-4090-87bd-ebfd2c424ac8} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:46158) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:46.533257 [ 18288 ] {9e99b9d7-0abf-4090-87bd-ebfd2c424ac8} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:47.025781 [ 10931 ] {74ad627b-9ec0-4173-9534-1c32087ca49f} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:46188) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:47.027800 [ 10931 ] {74ad627b-9ec0-4173-9534-1c32087ca49f} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:47.704232 [ 18288 ] {0b469d06-f212-4d2b-8714-7ea446901c10} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:46194) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:47.705889 [ 18288 ] {0b469d06-f212-4d2b-8714-7ea446901c10} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:48.239064 [ 18288 ] {072fc848-fa8a-4dbe-bd66-b242b2fbeea4} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:46212) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:48.241677 [ 18288 ] {072fc848-fa8a-4dbe-bd66-b242b2fbeea4} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:48.822331 [ 18288 ] {7168927e-c971-436d-abee-c8cd09849000} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:46224) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:48.824167 [ 18288 ] {7168927e-c971-436d-abee-c8cd09849000} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:49.491347 [ 18288 ] {5dce0c8b-7275-4b7a-9707-8d974fbcb148} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45346) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:49.493085 [ 18288 ] {5dce0c8b-7275-4b7a-9707-8d974fbcb148} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:50.119776 [ 18288 ] {d23a2900-7d65-400e-8436-651ddcef08e5} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45362) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:50.121443 [ 18288 ] {d23a2900-7d65-400e-8436-651ddcef08e5} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:50.640667 [ 18288 ] {39c14f50-8a3a-4246-8eee-2abf17ec6521} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45370) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:50.643836 [ 18288 ] {39c14f50-8a3a-4246-8eee-2abf17ec6521} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:51.078509 [ 2979 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:59:51.148073 [ 18288 ] {891b596d-b9f7-4a89-b267-f35912412fb8} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45378) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:51.149755 [ 18288 ] {891b596d-b9f7-4a89-b267-f35912412fb8} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:51.620987 [ 18288 ] {dc5b6147-f9c3-4daa-a82c-98220747d68b} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45388) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:51.622559 [ 18288 ] {dc5b6147-f9c3-4daa-a82c-98220747d68b} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:52.096453 [ 10931 ] {69db736a-3175-429b-9ac7-c6da739d4979} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45408) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:52.098442 [ 10931 ] {69db736a-3175-429b-9ac7-c6da739d4979} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:52.631255 [ 18288 ] {fa816bb3-3c64-43c5-84cd-2231190b7a43} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45420) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:52.633119 [ 18288 ] {fa816bb3-3c64-43c5-84cd-2231190b7a43} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:53.136943 [ 10931 ] {80844c79-15b4-4a25-9f4d-b32d7b41685a} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45440) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:53.138499 [ 10931 ] {80844c79-15b4-4a25-9f4d-b32d7b41685a} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:53.701915 [ 18288 ] {d458d8a1-7e51-40de-a695-6a3484fe8632} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45444) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:53.703871 [ 18288 ] {d458d8a1-7e51-40de-a695-6a3484fe8632} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:54.197347 [ 18288 ] {09aeebdd-6078-4622-b8fc-d0a217f43ff1} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45456) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:54.199166 [ 18288 ] {09aeebdd-6078-4622-b8fc-d0a217f43ff1} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:54.704629 [ 18288 ] {263ccd70-47fb-42d1-bc29-3b837ec3c6e0} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45480) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:54.706224 [ 18288 ] {263ccd70-47fb-42d1-bc29-3b837ec3c6e0} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:55.176943 [ 18288 ] {cadc6b4c-68ce-4880-9bb3-d3478cefbee3} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45494) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:55.179027 [ 18288 ] {cadc6b4c-68ce-4880-9bb3-d3478cefbee3} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:55.644896 [ 18288 ] {d9e3cf4e-f343-4db0-87cf-1702708b6316} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45522) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:55.646092 [ 18288 ] {d9e3cf4e-f343-4db0-87cf-1702708b6316} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:56.136902 [ 18288 ] {26d65534-f139-4400-ad8f-63a63e47c7aa} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45524) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:56.138520 [ 18288 ] {26d65534-f139-4400-ad8f-63a63e47c7aa} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:56.235717 [ 2710 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:59:56.632638 [ 10931 ] {1a828e23-0dfb-425e-a9bf-3f8410f93df2} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45540) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:56.634232 [ 10931 ] {1a828e23-0dfb-425e-a9bf-3f8410f93df2} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:56.883730 [ 5100 ] {} ExternalDictionariesLoader: Could not update external dictionary '4d942a90-5124-4d50-8e84-011027e2fc87', leaving the previous version, next update is scheduled at 2025-10-24 00:00:02: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bfc297 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000019bfd21f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f57e90 13. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:0: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000170291cf 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f581e4 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019bf9bd6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bf97d5 17. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x0000000019abec34 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aba072 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c63e3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 25. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 26. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a30a201 31. ./build_docker/./src/Dictionaries/DictionaryPipelineExecutor.cpp:0: DB::DictionaryPipelineExecutor::pull(DB::Block&) @ 0x000000000ff54611 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:59:57.018324 [ 2777 ] {} RefreshTask: Refresh view test_13.e failed (attempt 1/1): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 15. ./src/Interpreters/InterpreterCreateQuery.h:29: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x0000000017c5085a 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1535: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4da81 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 18. ./build_docker/./src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x00000000192bab92 19. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:380: DB::RefreshTask::executeRefreshUnlocked(bool) @ 0x0000000019ff6028 20. ./contrib/llvm-project/libcxx/include/__mutex_base:207: DB::RefreshTask::refreshTask() @ 0x0000000019ff46e8 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019ff7522 22. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 24. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:59:57.206207 [ 18288 ] {df6488c5-c987-459a-9e28-154eead43b05} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45556) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:57.207889 [ 18288 ] {df6488c5-c987-459a-9e28-154eead43b05} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:57.714584 [ 10931 ] {88c5f9f4-40bc-42d4-ac03-e9271a42f84a} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45570) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:57.716505 [ 10931 ] {88c5f9f4-40bc-42d4-ac03-e9271a42f84a} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:58.225785 [ 18288 ] {6af03272-0336-4d82-85eb-32f35067b900} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45572) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:58.228608 [ 18288 ] {6af03272-0336-4d82-85eb-32f35067b900} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:58.741831 [ 10931 ] {16fbe196-0941-4e7e-9aed-102a5ed7b2a0} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:45588) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:58.743620 [ 10931 ] {16fbe196-0941-4e7e-9aed-102a5ed7b2a0} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:59.243713 [ 2697 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.23 23:59:59.269398 [ 18288 ] {3a4adbd1-f5a8-4c2d-945b-d2a5437f52ff} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59680) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:59.271418 [ 18288 ] {3a4adbd1-f5a8-4c2d-945b-d2a5437f52ff} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:59.788474 [ 10931 ] {685b3a1a-dddd-4c30-93eb-d7cd547a574f} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59704) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.23 23:59:59.789936 [ 10931 ] {685b3a1a-dddd-4c30-93eb-d7cd547a574f} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:00:00.252671 [ 18288 ] {dae33f1b-7607-4ed3-87c1-2509cf3483a1} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59712) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:00:00.254251 [ 18288 ] {dae33f1b-7607-4ed3-87c1-2509cf3483a1} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:00:00.751731 [ 18288 ] {cfc7501e-36b6-4d01-acac-01049fdfddcd} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59720) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:00:00.752814 [ 18288 ] {cfc7501e-36b6-4d01-acac-01049fdfddcd} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:00:01.021823 [ 3187 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:01.240436 [ 18288 ] {f1a72f90-8988-40e7-94b6-507d779a03af} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59734) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:00:01.241872 [ 18288 ] {f1a72f90-8988-40e7-94b6-507d779a03af} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:00:01.751697 [ 18288 ] {f9fe0d37-9a11-4dd5-857e-a117fa2e9a14} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59736) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:00:01.753494 [ 18288 ] {f9fe0d37-9a11-4dd5-857e-a117fa2e9a14} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:00:02.333409 [ 18288 ] {044b80b3-c6bc-436d-8c51-ad3a7ac9b275} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59760) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:00:02.334350 [ 18288 ] {044b80b3-c6bc-436d-8c51-ad3a7ac9b275} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:00:02.833624 [ 18288 ] {8a8d66a2-a0c2-4b71-85e1-c50592c0e55f} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59776) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:00:02.835371 [ 18288 ] {8a8d66a2-a0c2-4b71-85e1-c50592c0e55f} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:00:03.253339 [ 2705 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:03.403691 [ 18288 ] {a3659666-695d-474e-99c1-a7351f3f1b96} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59786) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:00:03.405881 [ 18288 ] {a3659666-695d-474e-99c1-a7351f3f1b96} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:00:03.964775 [ 10931 ] {71aa207f-e7e0-4657-9f37-ca613181b587} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59798) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:00:03.965905 [ 10931 ] {71aa207f-e7e0-4657-9f37-ca613181b587} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:00:04.535199 [ 18288 ] {657eb9f7-6e3b-4ed2-a269-a2d5a1287687} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59800) (comment: 02496_remove_redundant_sorting.sh) (in query: SET enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:00:04.537322 [ 18288 ] {657eb9f7-6e3b-4ed2-a269-a2d5a1287687} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:00:05.155973 [ 10931 ] {3c216c55-264d-482d-a89d-19cc201e94b4} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59810) (comment: 01825_type_json_partitions.sql) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:00:05.157900 [ 10931 ] {3c216c55-264d-482d-a89d-19cc201e94b4} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:00:05.258410 [ 2703 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:06.941842 [ 18288 ] {b7636180-5b2e-4088-bdd2-a2910b696059} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59836) (comment: 01825_type_json_empty_string.sql) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:00:06.943709 [ 18288 ] {b7636180-5b2e-4088-bdd2-a2910b696059} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:00:09.267945 [ 2709 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:10.136254 [ 3320 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {31dc9f48-44c4-4df8-94b6-f5019085f4b9::202510_1_76_15}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:10.183282 [ 18288 ] {ffa4bac6-177f-4c69-adab-48a70d2d5369} executeQuery: Code: 42. DB::Exception: Number of arguments for function neighbor doesn't match: passed 0, should be from 2 to 3: In scope SELECT neighbor(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43994) (comment: 00957_neighbor.sql) (in query: -- no arguments select neighbor();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x0000000007bd4526 4. DB::(anonymous namespace)::FunctionNeighbor::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cfb2bee 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007614924 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:00:10.183909 [ 18288 ] {ffa4bac6-177f-4c69-adab-48a70d2d5369} TCPHandler: Code: 42. DB::Exception: Number of arguments for function neighbor doesn't match: passed 0, should be from 2 to 3: In scope SELECT neighbor(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x0000000007bd4526 4. DB::(anonymous namespace)::FunctionNeighbor::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cfb2bee 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007614924 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:00:10.191017 [ 18288 ] {6039336e-3680-4c00-a885-230d0faca2de} executeQuery: Code: 42. DB::Exception: Number of arguments for function neighbor doesn't match: passed 1, should be from 2 to 3: In scope SELECT neighbor(1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43994) (comment: 00957_neighbor.sql) (in query: -- single argument select neighbor(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x0000000007bd4526 4. DB::(anonymous namespace)::FunctionNeighbor::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cfb2bee 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007614924 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:00:10.191517 [ 18288 ] {6039336e-3680-4c00-a885-230d0faca2de} TCPHandler: Code: 42. DB::Exception: Number of arguments for function neighbor doesn't match: passed 1, should be from 2 to 3: In scope SELECT neighbor(1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x0000000007bd4526 4. DB::(anonymous namespace)::FunctionNeighbor::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cfb2bee 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007614924 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:00:10.198071 [ 18288 ] {0b89a186-119a-4e31-8c01-34898b0a111e} executeQuery: Code: 42. DB::Exception: Number of arguments for function neighbor doesn't match: passed 4, should be from 2 to 3: In scope SELECT neighbor(1, 2, 3, 4). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43994) (comment: 00957_neighbor.sql) (in query: -- greater than 3 arguments select neighbor(1,2,3,4);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x0000000007bd4526 4. DB::(anonymous namespace)::FunctionNeighbor::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cfb2bee 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007614924 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:00:10.198516 [ 18288 ] {0b89a186-119a-4e31-8c01-34898b0a111e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function neighbor doesn't match: passed 4, should be from 2 to 3: In scope SELECT neighbor(1, 2, 3, 4). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x0000000007bd4526 4. DB::(anonymous namespace)::FunctionNeighbor::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cfb2bee 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007614924 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:00:10.757574 [ 18288 ] {1e2467ab-7220-4adc-b861-683027b18cc2} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt8, String because some of them are String/FixedString/Enum and some of them are not: In scope SELECT neighbor(dummy, 1, 'hello'). (NO_COMMON_TYPE) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43994) (comment: 00957_neighbor.sql) (in query: -- bad default value select neighbor(dummy, 1, 'hello');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000d49b246 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000016f3f460 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:528: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000016f44ca3 6. DB::(anonymous namespace)::FunctionNeighbor::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cfb29c4 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007614924 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.24 00:00:10.758772 [ 18288 ] {1e2467ab-7220-4adc-b861-683027b18cc2} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt8, String because some of them are String/FixedString/Enum and some of them are not: In scope SELECT neighbor(dummy, 1, 'hello'). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000d49b246 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000016f3f460 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:528: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000016f44ca3 6. DB::(anonymous namespace)::FunctionNeighbor::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cfb29c4 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007614924 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.24 00:00:11.363170 [ 18288 ] {f10d4fe7-04f8-4287-873a-684ccfdd7a81} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int8, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: In scope SELECT number, neighbor(number, 1, -10) FROM numbers(3). (NO_COMMON_TYPE) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43994) (comment: 00957_neighbor.sql) (in query: -- types without common supertype (UInt64 and Int8) select number, neighbor(number, 1, -10) from numbers(3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000d49b246 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x0000000016f40640 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:176: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x0000000016f404df 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000016f44601 7. DB::(anonymous namespace)::FunctionNeighbor::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cfb29c4 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007614924 9. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 2025.10.24 00:00:11.412853 [ 18288 ] {f10d4fe7-04f8-4287-873a-684ccfdd7a81} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int8, UInt64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: In scope SELECT number, neighbor(number, 1, -10) FROM numbers(3). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000d49b246 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x0000000016f40640 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:176: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x0000000016f404df 6. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000016f44601 7. DB::(anonymous namespace)::FunctionNeighbor::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cfb29c4 8. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007614924 9. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 2025.10.24 00:00:11.747791 [ 18288 ] {b0b72660-49ca-49d4-b79f-f5227f74d0e6} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(UInt64) of second argument of function neighbor - should be an integer: In scope SELECT number, if(number > 1, number, NULL) AS offset, neighbor(number, offset) FROM numbers(3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43994) (comment: 00957_neighbor.sql) (in query: -- nullable offset is not allowed select number, if(number > 1, number, null) as offset, neighbor(number, offset) from numbers(3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::(anonymous namespace)::FunctionNeighbor::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cfb2d83 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007614924 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:00:11.748582 [ 18288 ] {b0b72660-49ca-49d4-b79f-f5227f74d0e6} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(UInt64) of second argument of function neighbor - should be an integer: In scope SELECT number, if(number > 1, number, NULL) AS offset, neighbor(number, offset) FROM numbers(3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. DB::(anonymous namespace)::FunctionNeighbor::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cfb2d83 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x0000000007614924 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b31 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:00:15.207758 [ 2786 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:17.290271 [ 2709 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:18.295385 [ 2706 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:22.306362 [ 2700 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:24.312271 [ 2696 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:30.327512 [ 2700 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1dfa7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:33.333260 [ 2709 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:35.337843 [ 2705 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:37.346662 [ 2703 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:38.350318 [ 2700 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:39.352388 [ 2697 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:40.355774 [ 2696 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:41.358714 [ 2709 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1dfa7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:42.023346 [ 3034 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:49.762587 [ 10929 ] {296fb89d-9bc3-467e-9aaa-0c9f343281d0} executeQuery: Code: 410. DB::Exception: BridgeHelper: clickhouse-odbc-bridge is not responding. (EXTERNAL_SERVER_IS_NOT_RESPONDING) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:40014) (comment: 01086_odbc_roundtrip.sh) (in query: select count() > 1 as ok from (select * from odbc('DSN={ClickHouse DSN (ANSI)}','system','tables'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/BridgeHelper/IBridgeHelper.cpp:0: DB::IBridgeHelper::startBridgeSync() @ 0x000000001a0d9a59 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::ITableFunctionXDBC::startBridgeIfNot(std::shared_ptr) const @ 0x0000000015ea5d74 6. ./build_docker/./src/TableFunctions/ITableFunctionXDBC.cpp:0: DB::(anonymous namespace)::ITableFunctionXDBC::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015ea567d 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 8. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1bbd 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d690b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:00:49.765831 [ 10929 ] {296fb89d-9bc3-467e-9aaa-0c9f343281d0} TCPHandler: Code: 410. DB::Exception: BridgeHelper: clickhouse-odbc-bridge is not responding. (EXTERNAL_SERVER_IS_NOT_RESPONDING), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/BridgeHelper/IBridgeHelper.cpp:0: DB::IBridgeHelper::startBridgeSync() @ 0x000000001a0d9a59 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::ITableFunctionXDBC::startBridgeIfNot(std::shared_ptr) const @ 0x0000000015ea5d74 6. ./build_docker/./src/TableFunctions/ITableFunctionXDBC.cpp:0: DB::(anonymous namespace)::ITableFunctionXDBC::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015ea567d 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 8. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1bbd 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d690b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:00:50.744123 [ 18288 ] {12a58323-8769-486a-9c9d-c4c528638adc} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 13.50 MiB (attempt to allocate chunk of 1052672 bytes), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:44044) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: insert into num_2 select number * 3, -number from numbers(1.5e6);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000000fa3705c 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa361e0 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa35c1e 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:0: CurrentMemoryTracker::alloc(long) @ 0x000000000f9c356f 7. ./src/Common/AllocatorWithMemoryTracking.h:0: std::deque>::__add_back_capacity() @ 0x000000001a2fda7e 8. ./contrib/llvm-project/libcxx/include/deque:0: DB::ExecutingGraph::updateNode(unsigned long, std::queue>>&, std::queue>>&) @ 0x000000001a2faaa4 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:292: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f549d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f356a 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.24 00:00:50.846764 [ 18288 ] {12a58323-8769-486a-9c9d-c4c528638adc} TCPHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 13.50 MiB (attempt to allocate chunk of 1052672 bytes), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000000fa3705c 4. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa361e0 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fa35c1e 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:0: CurrentMemoryTracker::alloc(long) @ 0x000000000f9c356f 7. ./src/Common/AllocatorWithMemoryTracking.h:0: std::deque>::__add_back_capacity() @ 0x000000001a2fda7e 8. ./contrib/llvm-project/libcxx/include/deque:0: DB::ExecutingGraph::updateNode(unsigned long, std::queue>>&, std::queue>>&) @ 0x000000001a2faaa4 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:292: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f549d 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 12. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f356a 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.24 00:00:51.795535 [ 10929 ] {28b917e2-1b12-4e67-9927-da2abab6780f} virtual DB::ConcurrentHashJoin::~ConcurrentHashJoin(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017737c93 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:313: std::__shared_ptr_emplace>::__on_zero_shared() @ 0x0000000017709488 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:216: DB::JoinStep::~JoinStep() @ 0x000000001a907890 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::QueryPlan::~QueryPlan() @ 0x000000001a91f3f9 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Planner::~Planner() @ 0x00000000177319ae 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc30bf 13. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:0: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000017de1df4 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcaf29 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 16. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:52.428774 [ 10929 ] {28b917e2-1b12-4e67-9927-da2abab6780f} DB::ConcurrentHashJoin::ConcurrentHashJoin(ContextPtr, std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017737538 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000017e1b9ba 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017df9710 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de9fd2 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcad8b 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 14. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:0: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x00000000195af4d8 15. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:355: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x00000000195ab9e5 16. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:416: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000017de1e8d 17. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcaf29 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:52.435376 [ 10929 ] {28b917e2-1b12-4e67-9927-da2abab6780f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47722) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings parallel_replicas_prefer_local_join=0) r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_local_plan=1, parallel_replicas_prefer_local_join=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017737538 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000017e1b9ba 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017df9710 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de9fd2 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcad8b 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 14. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:0: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x00000000195af4d8 15. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:355: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x00000000195ab9e5 16. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:416: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000017de1e8d 17. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcaf29 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.24 00:00:52.438636 [ 10929 ] {28b917e2-1b12-4e67-9927-da2abab6780f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017737538 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000017e1b9ba 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017df9710 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de9fd2 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcad8b 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 14. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:0: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x00000000195af4d8 15. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:355: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x00000000195ab9e5 16. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:416: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000017de1e8d 17. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcaf29 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.24 00:00:53.102261 [ 18288 ] {d0fd46d9-643a-4c9d-b44d-923cecc3e30e} DB::ConcurrentHashJoin::ConcurrentHashJoin(ContextPtr, std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017737538 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000017e1b9ba 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017df9710 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de9fd2 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcad8b 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getSampleBlock() @ 0x0000000017dc2ec9 14. ./src/Interpreters/InterpreterSelectQueryAnalyzer.h:13: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc30a5 15. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:0: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000017de1df4 16. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcaf29 17. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 18. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 28. __tsan_thread_start_func @ 0x000000000758df2f 29. ? @ 0x00007f7c69445ac3 30. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:53.105492 [ 18288 ] {d0fd46d9-643a-4c9d-b44d-923cecc3e30e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47728) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings parallel_replicas_prefer_local_join=0) r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_local_plan=1, send_logs_level='trace', parallel_replicas_prefer_local_join=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017737538 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000017e1b9ba 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017df9710 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de9fd2 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcad8b 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getSampleBlock() @ 0x0000000017dc2ec9 14. ./src/Interpreters/InterpreterSelectQueryAnalyzer.h:13: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc30a5 15. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:0: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000017de1df4 16. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcaf29 17. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 18. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 28. __tsan_thread_start_func @ 0x000000000758df2f 29. ? @ 0x00007f7c69445ac3 30. ? @ 0x00007f7c694d7850 2025.10.24 00:00:53.203234 [ 18288 ] {d0fd46d9-643a-4c9d-b44d-923cecc3e30e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017737538 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000017e1b9ba 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017df9710 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de9fd2 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcad8b 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getSampleBlock() @ 0x0000000017dc2ec9 14. ./src/Interpreters/InterpreterSelectQueryAnalyzer.h:13: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc30a5 15. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:0: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000017de1df4 16. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcaf29 17. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 18. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 28. __tsan_thread_start_func @ 0x000000000758df2f 29. ? @ 0x00007f7c69445ac3 30. ? @ 0x00007f7c694d7850 2025.10.24 00:00:53.878519 [ 18288 ] {29378c40-0cf6-4815-8725-e0221db97326} DB::ConcurrentHashJoin::ConcurrentHashJoin(ContextPtr, std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017737538 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000017e1b9ba 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017df9710 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de9fd2 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcad8b 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 13. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:0: DB::findQueryForParallelReplicas(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000017de0a7d 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000017dc4389 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf5d1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:53.888401 [ 18288 ] {29378c40-0cf6-4815-8725-e0221db97326} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47742) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings parallel_replicas_prefer_local_join=1) r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_local_plan=1, parallel_replicas_prefer_local_join=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017737538 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000017e1b9ba 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017df9710 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de9fd2 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcad8b 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 13. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:0: DB::findQueryForParallelReplicas(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000017de0a7d 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000017dc4389 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf5d1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.24 00:00:53.892424 [ 18288 ] {29378c40-0cf6-4815-8725-e0221db97326} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017737538 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000017e1b9ba 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017df9710 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de9fd2 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcad8b 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 13. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:0: DB::findQueryForParallelReplicas(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000017de0a7d 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000017dc4389 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:163: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf5d1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.24 00:00:54.970585 [ 18288 ] {116a5a94-7a5e-4e4a-80cf-3fa353c9bb9f} DB::ConcurrentHashJoin::ConcurrentHashJoin(ContextPtr, std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017737538 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000017e1b9ba 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017df9710 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de9fd2 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcad8b 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 14. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:0: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x00000000195af4d8 15. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:355: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x00000000195ab9e5 16. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:416: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000017de1e8d 17. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcaf29 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:54.976886 [ 18288 ] {116a5a94-7a5e-4e4a-80cf-3fa353c9bb9f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47744) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings parallel_replicas_prefer_local_join=1) r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_local_plan=1, send_logs_level='trace', parallel_replicas_prefer_local_join=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017737538 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000017e1b9ba 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017df9710 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de9fd2 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcad8b 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 14. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:0: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x00000000195af4d8 15. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:355: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x00000000195ab9e5 16. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:416: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000017de1e8d 17. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcaf29 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.24 00:00:54.983884 [ 18288 ] {116a5a94-7a5e-4e4a-80cf-3fa353c9bb9f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017737538 8. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000017e1b9ba 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017df9710 10. ./contrib/llvm-project/libcxx/include/vector:1596: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000017de9fd2 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcad8b 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 14. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:0: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x00000000195af4d8 15. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:355: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x00000000195ab9e5 16. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:416: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000017de1e8d 17. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcaf29 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 2025.10.24 00:00:55.577269 [ 3308 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {678af7ec-371a-476f-b893-c6848743a362::202510_1_95_19}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:56.291613 [ 18288 ] {2e5ddf89-d93f-4f3e-bfc5-43cef736b082} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=3): (while reading column key): (while reading from part /var/lib/clickhouse/store/c30/c302011d-4894-4bbc-b395-d75922ffcc4d/all_1_1_0/ in table test_1.num_1 (c302011d-4894-4bbc-b395-d75922ffcc4d) located on disk default of type local, from mark 0 with max_rows_to_read = 65409): While executing MergeTreeSelect(pool: ReadPoolParallelReplicasInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47754) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings join_algorithm='full_sorting_merge') r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_local_plan=1, parallel_replicas_prefer_local_join=0, join_algorithm='full_sorting_merge'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000016d64235 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d65c54 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d661ce 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fe4dcb 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f58c32 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x0000000019bfbc4a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bfb20e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a98c8ea 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 27. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 28. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 2025.10.24 00:00:56.294975 [ 18285 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:37488, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe5aed 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fbe4c7d 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fbe52f4 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:0: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a06adcf 6. DB::ReadBuffer::next() @ 0x0000000007b3717b 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001a1eb31a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:56.308160 [ 18288 ] {2e5ddf89-d93f-4f3e-bfc5-43cef736b082} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=3): (while reading column key): (while reading from part /var/lib/clickhouse/store/c30/c302011d-4894-4bbc-b395-d75922ffcc4d/all_1_1_0/ in table test_1.num_1 (c302011d-4894-4bbc-b395-d75922ffcc4d) located on disk default of type local, from mark 0 with max_rows_to_read = 65409): While executing MergeTreeSelect(pool: ReadPoolParallelReplicasInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000016d64235 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d65c54 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d661ce 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fe4dcb 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f58c32 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x0000000019bfbc4a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bfb20e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a98c8ea 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 27. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 28. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 2025.10.24 00:00:56.630478 [ 18288 ] {ed37f500-9cda-41e8-b539-5cb27c472eab} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47782) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings join_algorithm='full_sorting_merge') r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_local_plan=1, parallel_replicas_prefer_local_join=0, send_logs_level='trace', join_algorithm='full_sorting_merge'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f5511 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.24 00:00:56.632446 [ 18288 ] {ed37f500-9cda-41e8-b539-5cb27c472eab} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f5511 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.24 00:00:57.470943 [ 2709 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:58.009995 [ 3875 ] {57e6b716-7d3a-4a4c-a9ae-d24259d87329} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:43064) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`value` AS `value`, `__table3`.`key` AS `r.key`, `__table3`.`value` AS `r.value` FROM (SELECT `__table2`.`key` AS `key`, `__table2`.`value` AS `value` FROM `test_1`.`num_1` AS `__table2`) AS `__table1` GLOBAL ALL INNER JOIN `_data_6300796966449147400_7886010205147484669` AS `__table3` ON `__table1`.`key` = `__table3`.`key` ORDER BY `__table1`.`key` ASC LIMIT _CAST(10000, 'UInt64'), _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019afcfca 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001a947c35 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a94638f 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1454: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a946030 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1934: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9507fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8f5f22 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9210b9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dc3569 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017dc3210 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.24 00:00:58.012486 [ 3875 ] {57e6b716-7d3a-4a4c-a9ae-d24259d87329} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019afcfca 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001a947c35 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a94638f 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1454: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a946030 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1934: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9507fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8f5f22 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9210b9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dc3569 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017dc3210 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.24 00:00:58.019240 [ 18288 ] {bbfd04f6-c7c7-4ea9-a1e0-727f6ae48dbb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=1): (while reading column key): (while reading from part /var/lib/clickhouse/store/c30/c302011d-4894-4bbc-b395-d75922ffcc4d/all_3_3_0/ in table test_1.num_1 (c302011d-4894-4bbc-b395-d75922ffcc4d) located on disk default of type local, from mark 0 with max_rows_to_read = 57344): While executing MergeTreeSelect(pool: ReadPoolParallelReplicasInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47808) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings join_algorithm='hash') r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_local_plan=1, parallel_replicas_prefer_local_join=0, join_algorithm='full_sorting_merge'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000016d64235 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d65c54 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d661ce 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fe4dcb 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f58c32 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x0000000019bfbc4a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bfb20e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a98c8ea 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 27. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 28. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 2025.10.24 00:00:58.121137 [ 18288 ] {bbfd04f6-c7c7-4ea9-a1e0-727f6ae48dbb} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=1): (while reading column key): (while reading from part /var/lib/clickhouse/store/c30/c302011d-4894-4bbc-b395-d75922ffcc4d/all_3_3_0/ in table test_1.num_1 (c302011d-4894-4bbc-b395-d75922ffcc4d) located on disk default of type local, from mark 0 with max_rows_to_read = 57344): While executing MergeTreeSelect(pool: ReadPoolParallelReplicasInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000016d64235 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d65c54 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d661ce 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fe4dcb 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f58c32 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x0000000019bfbc4a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bfb20e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a98c8ea 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 27. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 28. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 2025.10.24 00:00:59.476844 [ 2705 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:59.939943 [ 18288 ] {d15405e1-b6ee-4688-b8c7-b06940926ed0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicasInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47820) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings join_algorithm='hash') r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_local_plan=1, parallel_replicas_prefer_local_join=0, send_logs_level='trace', join_algorithm='full_sorting_merge'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bfc297 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000019bfd21f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f57e90 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f581e4 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019bf9bd6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bf97d5 16. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x0000000019abec34 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aba072 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicasInOrder.cpp:84: DB::MergeTreeReadPoolParallelReplicasInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c3f70 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 2025.10.24 00:00:59.944536 [ 10929 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:39932, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe5aed 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fbe4c7d 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fbe52f4 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:0: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a06adcf 6. DB::ReadBuffer::next() @ 0x0000000007b3717b 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001a1eb31a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:00:59.960501 [ 18288 ] {d15405e1-b6ee-4688-b8c7-b06940926ed0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicasInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bfc297 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000019bfd21f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f57e90 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f581e4 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019bf9bd6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bf97d5 16. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x0000000019abec34 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aba072 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicasInOrder.cpp:84: DB::MergeTreeReadPoolParallelReplicasInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c3f70 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 2025.10.24 00:01:01.139489 [ 18288 ] {df0c4beb-6bbf-474d-aa5c-9cb1523310e9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43174) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings join_algorithm='full_sorting_merge') r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_local_plan=1, parallel_replicas_prefer_local_join=0, join_algorithm='hash'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2f303a 11. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:0: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x00000000195b00d4 12. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:355: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x00000000195ab9e5 13. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:416: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000017de1e8d 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcaf29 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 16. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 2025.10.24 00:01:01.141189 [ 18288 ] {df0c4beb-6bbf-474d-aa5c-9cb1523310e9} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000001a2f303a 11. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:0: DB::(anonymous namespace)::executeSubqueryNode(std::shared_ptr const&, std::shared_ptr&, unsigned long) @ 0x00000000195b00d4 12. ./build_docker/./src/Storages/buildQueryTreeForShard.cpp:355: DB::buildQueryTreeForShard(std::shared_ptr const&, std::shared_ptr) @ 0x00000000195ab9e5 13. ./build_docker/./src/Planner/findParallelReplicasQuery.cpp:416: DB::buildQueryPlanForParallelReplicas(DB::QueryNode const&, std::shared_ptr const&, std::shared_ptr> const>) @ 0x0000000017de1e8d 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dcaf29 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 16. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 2025.10.24 00:01:01.821447 [ 18288 ] {ec6bab72-7c7e-44f7-bcad-ee6c2494d3ad} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43186) (comment: 02967_parallel_replicas_join_algo_and_analyzer_3.sh) (in query: select * from (select key, value from num_1) l inner join (select key, value from num_2 inner join (select number * 7 as key from numbers(1e5)) as nn on num_2.key = nn.key settings join_algorithm='full_sorting_merge') r on l.key = r.key order by l.key limit 10 offset 10000 SETTINGS enable_analyzer=1, enable_parallel_replicas = 2, max_parallel_replicas = 2, parallel_replicas_for_non_replicated_merge_tree = 1, cluster_for_parallel_replicas = 'test_cluster_one_shard_three_replicas_localhost', parallel_replicas_local_plan=1, parallel_replicas_prefer_local_join=0, send_logs_level='trace', join_algorithm='hash'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f5511 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.24 00:01:01.824283 [ 18288 ] {ec6bab72-7c7e-44f7-bcad-ee6c2494d3ad} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f5511 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.24 00:01:02.015608 [ 8855 ] {} ExternalDictionariesLoader: Could not update external dictionary '4d942a90-5124-4d50-8e84-011027e2fc87', leaving the previous version, next update is scheduled at 2025-10-24 00:01:07: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=0): (while reading column second_column): (while reading from part /var/lib/clickhouse/store/847/8471dccc-d02b-4a9b-be32-a2c153b48d95/all_1_1_0/ in table database_for_dict.table_for_dict (8471dccc-d02b-4a9b-be32-a2c153b48d95) located on disk default of type local, from mark 0 with max_rows_to_read = 100): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000016d64235 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d65c54 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d661ce 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fe0f1e 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f58c32 18. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:0: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000001702b604 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x0000000019bfbc4a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bfb20e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a98c8ea 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 28. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 29. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:01:02.412296 [ 18288 ] {c2c5b55e-6188-4978-9ccc-47c4929046b1} executeQuery: Code: 57. DB::Exception: Table test_1.test_table already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43194) (comment: 02525_analyzer_function_in_crash_fix.sql) (in query: CREATE TABLE test_table (`id` UInt8, `value` Nullable(Decimal(38, 2))) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 46333, min_bytes_for_wide_part = 811366735, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 122, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 63755872, compact_parts_max_granules_to_buffer = 199, compact_parts_merge_max_bytes_to_prefetch_part = 19901130, merge_max_block_size = 6864, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 22859310, concurrent_part_removal_threshold = 22, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 60882, primary_key_compress_block_size = 51736), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.24 00:01:02.414651 [ 18288 ] {c2c5b55e-6188-4978-9ccc-47c4929046b1} TCPHandler: Code: 57. DB::Exception: Table test_1.test_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.24 00:01:03.487807 [ 2697 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:01:10.022493 [ 2893 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:01:10.543640 [ 18285 ] {10c2efc2-3081-4769-8dcb-acca5fe934a8} executeQuery: Code: 57. DB::Exception: Table test_1.test_parquet already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50146) (comment: 03215_parquet_index.sql) (in query: CREATE TABLE test_parquet (col1 int, col2 String) ENGINE=File(Parquet) SETTINGS output_format_parquet_use_custom_encoder=false, output_format_parquet_write_page_index=true;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.24 00:01:10.545215 [ 18285 ] {10c2efc2-3081-4769-8dcb-acca5fe934a8} TCPHandler: Code: 57. DB::Exception: Table test_1.test_parquet already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.24 00:01:11.206737 [ 2825 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:01:16.612954 [ 2710 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:01:21.625672 [ 2709 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:01:23.631899 [ 2705 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1dfa7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:01:24.634028 [ 2710 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:01:25.637338 [ 2703 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:01:26.640739 [ 2700 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:01:27.643584 [ 2697 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:01:31.432593 [ 18285 ] {7f84fc73-7ea0-4c9c-8470-c4413989474f} executeQuery: Code: 660. DB::Exception: Unable to connect to HDFS: Hdfs::HdfsRpcException: HdfsFailoverException: Failed to invoke RPC call "getFsStats" on server "localhost:12222" Caused by: HdfsNetworkConnectException: Connect to "localhost:12222" failed: (errno: 111) Connection refused. (HDFS_ERROR) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50156) (comment: 02244_hdfs_cluster.sql) (in query: insert into table function hdfs('hdfs://localhost:12222/test_1.tsv', 'TSV', 'column1 UInt32, column2 UInt32, column3 UInt32') select 1, 2, 3 settings hdfs_truncate_on_insert=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Storages/ObjectStorage/HDFS/HDFSCommon.cpp:0: DB::createHDFSFS(hdfsBuilder*) @ 0x00000000163eeb58 5. ./build_docker/./src/Disks/ObjectStorages/HDFS/HDFSObjectStorage.cpp:35: DB::HDFSObjectStorage::initializeHDFSFS() const @ 0x00000000165c83f5 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::HDFSObjectStorage::writeObject(DB::StoredObject const&, DB::WriteMode, std::optional, std::allocator>>>, unsigned long, DB::WriteSettings const&) @ 0x00000000165ca2a2 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:0: DB::StorageObjectStorageSink::StorageObjectStorageSink(std::shared_ptr, std::shared_ptr, std::optional const&, DB::Block const&, std::shared_ptr, String const&) @ 0x0000000016387a69 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageObjectStorageSink* std::construct_at[abi:v15007] const&, std::shared_ptr, std::optional const&, DB::Block const&, std::shared_ptr&, DB::StorageObjectStorageSink*>(DB::StorageObjectStorageSink*, std::shared_ptr const&, std::shared_ptr&&, std::optional const&, DB::Block const&, std::shared_ptr&) @ 0x000000001638062b 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:0: DB::StorageObjectStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000016379523 10. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a79ae1d 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000017d48f54 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d49eb8 13. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4c3d4 14. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f801 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.24 00:01:31.434609 [ 18285 ] {7f84fc73-7ea0-4c9c-8470-c4413989474f} TCPHandler: Code: 660. DB::Exception: Unable to connect to HDFS: Hdfs::HdfsRpcException: HdfsFailoverException: Failed to invoke RPC call "getFsStats" on server "localhost:12222" Caused by: HdfsNetworkConnectException: Connect to "localhost:12222" failed: (errno: 111) Connection refused. (HDFS_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Storages/ObjectStorage/HDFS/HDFSCommon.cpp:0: DB::createHDFSFS(hdfsBuilder*) @ 0x00000000163eeb58 5. ./build_docker/./src/Disks/ObjectStorages/HDFS/HDFSObjectStorage.cpp:35: DB::HDFSObjectStorage::initializeHDFSFS() const @ 0x00000000165c83f5 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::HDFSObjectStorage::writeObject(DB::StoredObject const&, DB::WriteMode, std::optional, std::allocator>>>, unsigned long, DB::WriteSettings const&) @ 0x00000000165ca2a2 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:0: DB::StorageObjectStorageSink::StorageObjectStorageSink(std::shared_ptr, std::shared_ptr, std::optional const&, DB::Block const&, std::shared_ptr, String const&) @ 0x0000000016387a69 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageObjectStorageSink* std::construct_at[abi:v15007] const&, std::shared_ptr, std::optional const&, DB::Block const&, std::shared_ptr&, DB::StorageObjectStorageSink*>(DB::StorageObjectStorageSink*, std::shared_ptr const&, std::shared_ptr&&, std::optional const&, DB::Block const&, std::shared_ptr&) @ 0x000000001638062b 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:0: DB::StorageObjectStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000016379523 10. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a79ae1d 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000017d48f54 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d49eb8 13. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4c3d4 14. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f801 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.24 00:01:33.656197 [ 2703 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:01:36.381864 [ 18288 ] {17d7b3d5-1f5b-48a7-af80-6a06d1599a52} executeQuery: Code: 80. DB::Exception: Cannot MATERIALIZE TTL as there is no TTL set for table test_1.ttl (5574c7e5-b3cd-4b9e-94c6-9f0c0e807ab7). (INCORRECT_QUERY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43830) (comment: 01070_materialize_ttl.sql) (in query: alter table ttl materialize ttl;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c29912 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.24 00:01:36.385004 [ 18288 ] {17d7b3d5-1f5b-48a7-af80-6a06d1599a52} TCPHandler: Code: 80. DB::Exception: Cannot MATERIALIZE TTL as there is no TTL set for table test_1.ttl (5574c7e5-b3cd-4b9e-94c6-9f0c0e807ab7). (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c29912 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.24 00:01:36.747767 [ 18288 ] {e29203d7-e67b-45f3-9460-3e22e1ebdefe} executeQuery: Code: 57. DB::Exception: Table test_1.ttl already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43830) (comment: 01070_materialize_ttl.sql) (in query: CREATE TABLE ttl (`i` Int, `s` String) ENGINE = MergeTree ORDER BY i SETTINGS index_granularity = 8936, min_bytes_for_wide_part = 23839938, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 29, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 449811037, compact_parts_max_granules_to_buffer = 159, compact_parts_merge_max_bytes_to_prefetch_part = 12108014, merge_max_block_size = 4740, old_parts_lifetime = 344., prefer_fetch_merged_part_size_threshold = 10092975919, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 2332868723, index_granularity_bytes = 25345316, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 14174, primary_key_compress_block_size = 42702), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.24 00:01:36.748759 [ 18288 ] {e29203d7-e67b-45f3-9460-3e22e1ebdefe} TCPHandler: Code: 57. DB::Exception: Table test_1.ttl already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.24 00:01:39.674752 [ 2705 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:01:40.083420 [ 3131 ] {} RefreshTask: Refresh view test_13.e failed (attempt 1/1): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 15. ./src/Interpreters/InterpreterCreateQuery.h:29: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x0000000017c5085a 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1535: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4da81 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 18. ./build_docker/./src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x00000000192bab92 19. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:380: DB::RefreshTask::executeRefreshUnlocked(bool) @ 0x0000000019ff6028 20. ./contrib/llvm-project/libcxx/include/__mutex_base:207: DB::RefreshTask::refreshTask() @ 0x0000000019ff46e8 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019ff7522 22. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 24. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:01:41.828371 [ 10929 ] {16f047dd-c4fe-4105-a8c4-d43f7b3d29ce} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:38598) (comment: 00158_cache_dictionary_has.sql) (in query: SELECT count() from test.hits PREWHERE WatchID % 1400 == 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.24 00:01:41.829766 [ 10929 ] {16f047dd-c4fe-4105-a8c4-d43f7b3d29ce} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.24 00:01:42.681484 [ 2700 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:01:43.625844 [ 18285 ] {bdcd80d3-dad2-42d1-9b01-855e74a8eb9b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=777, jobs=728). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:38626) (in query: select last_refresh_result from refreshes -- 50), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:01:43.628146 [ 18285 ] {bdcd80d3-dad2-42d1-9b01-855e74a8eb9b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=777, jobs=728). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:01:44.807364 [ 3316 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a53b52a7-30bb-4113-8a6d-7dc62d6781f8::202510_1_91_18}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:01:45.687390 [ 2709 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:01:46.690480 [ 2706 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:01:49.697646 [ 2703 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1dfa7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:01:51.972788 [ 2754 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:01:52.663737 [ 18285 ] {1517e7cf-d044-4bf5-8c4a-98cb296e4465} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=777, jobs=741). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43370) (comment: 02932_query_settings_max_size_drop.sql) (in query: CREATE TABLE test_max_size_drop ENGINE = MergeTree ORDER BY number SETTINGS index_granularity = 45576, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 3, min_bytes_for_full_part_storage = 286198050, compact_parts_max_bytes_to_buffer = 356249003, compact_parts_max_granules_to_buffer = 41, compact_parts_merge_max_bytes_to_prefetch_part = 18775713, merge_max_block_size = 11732, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 11093386, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 46509, primary_key_compress_block_size = 64121 AS SELECT number FROM numbers(1000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f2d53 8. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000001a1ec1ec 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.24 00:01:52.665058 [ 18285 ] {1517e7cf-d044-4bf5-8c4a-98cb296e4465} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=777, jobs=741). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f2d53 8. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000001a1ec1ec 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.24 00:01:55.714698 [ 2705 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:01:56.716515 [ 2710 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:01:58.721863 [ 2700 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:01.728002 [ 3875 ] {f0cf9bad-5bad-469d-923d-96cbfabecd30} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:54778) (comment: 00022_merge_prewhere.sql) (in query: DROP TABLE IF EXISTS test.merge_hits;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1e9f1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c766aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c74615 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c739c9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:02:01.729652 [ 3875 ] {f0cf9bad-5bad-469d-923d-96cbfabecd30} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1e9f1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c766aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c74615 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c739c9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:02:02.019243 [ 2981 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:02.076903 [ 5110 ] {} ExternalDictionariesLoader: Could not update external dictionary '36ef1abc-abab-4f85-93c6-36b673161500', leaving the previous version, next update is scheduled at 2025-10-24 00:02:07: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019afcfca 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001a947c35 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a94638f 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1454: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a946030 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1934: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9507fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8f5f22 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9210b9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dc3569 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017dc3210 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000000fe64c6e 19. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:115: DB::ClickHouseDictionarySource::loadAll() @ 0x000000000fe64b68 20. DB::FlatDictionary::loadData() @ 0x000000000ff59b00 21. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000ff592e0 22. std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration const&, std::shared_ptr const&, void>(std::allocator const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::FlatDictionary::Configuration const&, std::shared_ptr const&) @ 0x000000000ff8e02b 23. DB::FlatDictionary::clone() const @ 0x000000000ff81967 24. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1519: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x0000000017be631f 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000017be1eb1 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000017bea528 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000017bea322 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 30. __tsan_thread_start_func @ 0x000000000758df2f 31. ? @ 0x00007f7c69445ac3 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:03.957544 [ 3875 ] {a0e3928a-67c8-4f45-a112-362cae829583} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:54822) (comment: 00021_2_select_with_in.sql) (in query: select sum(Sign) from test.visits where CounterID in (942285, 577322);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.24 00:02:03.959351 [ 3875 ] {a0e3928a-67c8-4f45-a112-362cae829583} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.24 00:02:08.759858 [ 2696 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:15.430957 [ 21658 ] {ae0b3129-2f98-4d66-a262-27176678e23e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=777, jobs=747). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:52098) (comment: 03231_restore_user_with_existing_role.sh) (in query: BACKUP TABLE system.users, TABLE system.roles TO Disk('backups', '03231_restore_user_with_existing_role_test_13') FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:02:15.432245 [ 21658 ] {ae0b3129-2f98-4d66-a262-27176678e23e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=777, jobs=747). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:02:18.883540 [ 2706 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:19.909305 [ 2705 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:20.929120 [ 2710 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:20.964151 [ 18285 ] {ade65238-be50-4bc8-a5b9-5c0232287ee7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=777, jobs=747). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57588) (comment: 00081_group_by_without_key_and_totals.sql) (in query: SELECT TraficSourceID AS k, count() AS c FROM test.hits WHERE CounterID = 1704509 GROUP BY k WITH TOTALS ORDER BY k SETTINGS totals_mode = 'after_having_auto', max_rows_to_group_by = 100000, group_by_overflow_mode = 'any';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:02:20.984425 [ 18285 ] {ade65238-be50-4bc8-a5b9-5c0232287ee7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=777, jobs=747). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:02:22.526216 [ 3875 ] {e7e81972-2caa-473d-af8e-5b2e0c62afb1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57774) (comment: 00082_quantiles.sql) (in query: SELECT CounterID AS k, quantileExact(0.5)(ResolutionWidth) FROM test.hits GROUP BY k ORDER BY count() DESC, CounterID LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.24 00:02:22.539007 [ 3875 ] {e7e81972-2caa-473d-af8e-5b2e0c62afb1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.24 00:02:24.523061 [ 21658 ] {3db219cf-9b9e-4fc9-a494-cccd2a09fe2f} BackupsWorker: Failed to restore from backup Disk('backups', '03231_restore_user_with_existing_role_test_13'): Code: 493. DB::Exception: Cannot restore user `user_a_03231_restore_user_with_existing_role_test_13` because it already exists: While restoring data of table system.roles. (ACCESS_ENTITY_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Access/AccessBackup.cpp:0: DB::(anonymous namespace)::checkExistingEntities(std::vector, DB::UUIDTag>, std::shared_ptr>, std::allocator, DB::UUIDTag>, std::shared_ptr>>>&, std::unordered_map, DB::UUIDTag>, StrongTypedef, DB::UUIDTag>, std::hash, DB::UUIDTag>>, std::equal_to, DB::UUIDTag>>, std::allocator, DB::UUIDTag> const, StrongTypedef, DB::UUIDTag>>>>&, DB::AccessControl const&, DB::RestoreAccessCreationMode)::$_0::operator()(std::pair, DB::UUIDTag>, std::shared_ptr> const&) const @ 0x00000000167aeb4e 5. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::AccessRestorerFromBackup::getAccessEntities(DB::AccessControl const&) const @ 0x00000000167ae3bb 6. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::RestorerFromBackup::getAccessEntitiesToRestore() @ 0x000000001694d505 7. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::restoreFromBackup(DB::RestorerFromBackup&) @ 0x0000000016791c44 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::MultipleAccessStorage::restoreFromBackup(DB::RestorerFromBackup&) @ 0x00000000167db696 9. ./build_docker/./src/Access/AccessControl.cpp:636: DB::AccessControl::restoreFromBackup(DB::RestorerFromBackup&) @ 0x00000000166bec41 10. ./build_docker/./src/Storages/System/StorageSystemRoles.cpp:77: DB::StorageSystemRoles::restoreDataFromBackup(DB::RestorerFromBackup&, String const&, std::optional, 7ul, std::allocator>>> const&) @ 0x000000001600869d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::RestorerFromBackup::insertDataToTableImpl(DB::QualifiedTableName const&, std::shared_ptr, String const&, std::optional, 7ul, std::allocator>>> const&) @ 0x000000001694ce89 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001695015a 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:863: ? @ 0x000000001694e600 14. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000101feb95 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001694e8ad 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:24.525749 [ 21658 ] {3db219cf-9b9e-4fc9-a494-cccd2a09fe2f} executeQuery: Code: 493. DB::Exception: Cannot restore user `user_a_03231_restore_user_with_existing_role_test_13` because it already exists: While restoring data of table system.roles. (ACCESS_ENTITY_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57928) (comment: 03231_restore_user_with_existing_role.sh) (in query: RESTORE ALL FROM Disk('backups', '03231_restore_user_with_existing_role_test_13') SETTINGS create_access='create' FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Access/AccessBackup.cpp:0: DB::(anonymous namespace)::checkExistingEntities(std::vector, DB::UUIDTag>, std::shared_ptr>, std::allocator, DB::UUIDTag>, std::shared_ptr>>>&, std::unordered_map, DB::UUIDTag>, StrongTypedef, DB::UUIDTag>, std::hash, DB::UUIDTag>>, std::equal_to, DB::UUIDTag>>, std::allocator, DB::UUIDTag> const, StrongTypedef, DB::UUIDTag>>>>&, DB::AccessControl const&, DB::RestoreAccessCreationMode)::$_0::operator()(std::pair, DB::UUIDTag>, std::shared_ptr> const&) const @ 0x00000000167aeb4e 5. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::AccessRestorerFromBackup::getAccessEntities(DB::AccessControl const&) const @ 0x00000000167ae3bb 6. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::RestorerFromBackup::getAccessEntitiesToRestore() @ 0x000000001694d505 7. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::restoreFromBackup(DB::RestorerFromBackup&) @ 0x0000000016791c44 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::MultipleAccessStorage::restoreFromBackup(DB::RestorerFromBackup&) @ 0x00000000167db696 9. ./build_docker/./src/Access/AccessControl.cpp:636: DB::AccessControl::restoreFromBackup(DB::RestorerFromBackup&) @ 0x00000000166bec41 10. ./build_docker/./src/Storages/System/StorageSystemRoles.cpp:77: DB::StorageSystemRoles::restoreDataFromBackup(DB::RestorerFromBackup&, String const&, std::optional, 7ul, std::allocator>>> const&) @ 0x000000001600869d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::RestorerFromBackup::insertDataToTableImpl(DB::QualifiedTableName const&, std::shared_ptr, String const&, std::optional, 7ul, std::allocator>>> const&) @ 0x000000001694ce89 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001695015a 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:863: ? @ 0x000000001694e600 14. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000101feb95 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001694e8ad 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.24 00:02:24.531197 [ 21658 ] {3db219cf-9b9e-4fc9-a494-cccd2a09fe2f} TCPHandler: Code: 493. DB::Exception: Cannot restore user `user_a_03231_restore_user_with_existing_role_test_13` because it already exists: While restoring data of table system.roles. (ACCESS_ENTITY_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Access/AccessBackup.cpp:0: DB::(anonymous namespace)::checkExistingEntities(std::vector, DB::UUIDTag>, std::shared_ptr>, std::allocator, DB::UUIDTag>, std::shared_ptr>>>&, std::unordered_map, DB::UUIDTag>, StrongTypedef, DB::UUIDTag>, std::hash, DB::UUIDTag>>, std::equal_to, DB::UUIDTag>>, std::allocator, DB::UUIDTag> const, StrongTypedef, DB::UUIDTag>>>>&, DB::AccessControl const&, DB::RestoreAccessCreationMode)::$_0::operator()(std::pair, DB::UUIDTag>, std::shared_ptr> const&) const @ 0x00000000167aeb4e 5. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::AccessRestorerFromBackup::getAccessEntities(DB::AccessControl const&) const @ 0x00000000167ae3bb 6. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::RestorerFromBackup::getAccessEntitiesToRestore() @ 0x000000001694d505 7. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::restoreFromBackup(DB::RestorerFromBackup&) @ 0x0000000016791c44 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::MultipleAccessStorage::restoreFromBackup(DB::RestorerFromBackup&) @ 0x00000000167db696 9. ./build_docker/./src/Access/AccessControl.cpp:636: DB::AccessControl::restoreFromBackup(DB::RestorerFromBackup&) @ 0x00000000166bec41 10. ./build_docker/./src/Storages/System/StorageSystemRoles.cpp:77: DB::StorageSystemRoles::restoreDataFromBackup(DB::RestorerFromBackup&, String const&, std::optional, 7ul, std::allocator>>> const&) @ 0x000000001600869d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::RestorerFromBackup::insertDataToTableImpl(DB::QualifiedTableName const&, std::shared_ptr, String const&, std::optional, 7ul, std::allocator>>> const&) @ 0x000000001694ce89 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001695015a 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:863: ? @ 0x000000001694e600 14. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000101feb95 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001694e8ad 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.24 00:02:26.545744 [ 3875 ] {18e2dc52-93ce-4225-9742-f7a2ca1d1e05} executeQuery: Code: 131. DB::Exception: Too large string size: 18446744073709551615. The maximum is: 17179869184.: While executing Native. (TOO_LARGE_STRING_SIZE) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:58052) (comment: 02683_native_too_large_size.sql) (in query: SELECT * FROM format('Native', 'WatchID Int64, JavaEnable Int16, Title String, GoodEvent Int16, EventTime DateTime, EventDate Date, CounterID Int32, ClientIP Int32, RegionID Int32, UserID Int64, CounterClass Int16, OS Int16, UserAgent Int16, URL String, Referer String, IsRefresh Int16, RefererCategoryID Int16, RefererRegionID Int32, URLCategoryID Int16, URLRegionID Int32, ResolutionWidth Int16, ResolutionHeight Int16, ResolutionDepth Int16, FlashMajor Int16, FlashMinor Int16, FlashMinor2 String, NetMajor Int16, NetMinor Int16, UserAgentMajor Int16, UserAgentMinor String, CookieEnable Int16, JavascriptEnable Int16, IsMobile Int16, MobilePhone Int16, MobilePhoneModel String, Params String, IPNetworkID Int32, TraficSourceID Int16, SearchEngineID Int16, SearchPhrase String, AdvEngineID Int32, IsArtifical Int16, WindowClientWidth Int16, WindowClientHeight Int16, ClientTimeZone Int16, ClientEventTime DateTime, SilverlightVersion1 Int16, SilverlightVersion2 Int16, SilverlightVersion3 Int32, SilverlightVersion4 Int16, PageCharset String, CodeVersion Int32, IsLink Int16, IsDownload Int16, IsNotBounce Int16, FUniqID Int64, OriginalURL String, HID Int32, IsOldCounter Int16, IsEvent Int16, IsParameter Int16, DontCountHits Int16, WithHash Int16, HitColor String, LocalEventTime DateTime, Age Int16, Sex Int16, Income Int16, Interests Int16, Robotness Int16, RemoteIP Int32, VindowName Int32, OpenerName Int32, HistoryLength Int16, BrowserLanguage String, BrowserCountry String, SocialNetwork String, SocialAction String, HTTPError Int16, SendTiming Int32, DNSTiming Int32, ConnectTiming Int32, ResponseStartTiming Int32, ResponseEndTiming Int32, FetchTiming Int32, SocialSourceNetworkID Int16, SocialSourcePage String, ParamPrice Int64, ParamOrderID String, ParamCurrency String, ParamCurrencyID Int16, OpenstatServiceName String, OpenstatCampaignID String, OpenstatAdID String, OpenstatSourceID String, UTMSource String, UTMMedium String, UTMCampaign String, UTMContent String, UTMTerm String, FromTag String, HasGCLID Int16, RefererHash Int64, URLHash Int64, CLID Int32', $$i WatchIDInt64c*5/ !p~ úFÚÓ“2ql!è–|¨@H²Ç=ÐŒWéòˆE&Ly¹ãk=÷±pæ1þž oíC»-ÞC_ìÒŒ\Û/E‚ÜJÛ{ JavaEnableInt16TitleString GoodEventInt16 EventTimeDateTime7ðâQn$äQÃ)äQ8*äQJîâQÉ ãQµ0äQ83äQ× äQÖ1ãQ EventDateDate>>>>>>>>>> CounterIDInt32ClientIPInt32®Æz·®Æz·®Æz·®Æz·º‹I`®Æz·É^{]É^{]gU®Æz·RegionIDInt32GGGG'GÅÅåGUserIDInt64× ’•:6×Ý× ’•:6×Ý× ’•:6×Ý× ’•:6×Ýq—íJd8 ÎKs}¡ï&n%Št"6&n%Št"6ƒs—yyçóf× ’•:6×Ý CounterClassInt16OSInt16'', UserAgentInt16URLString-http://holodilInt16WindowClientWidthInt16WindowClientHeightInt16ClientTimeZoneInt16ÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿClientEventTimeDateTimeîáîáîáîáîáîáîáîáîáîáSilverlightVersion1Int16SilverlightVersion2Int16SilverlightVersion3Int32SilverlightVersion4Int16 PageCharsetString CodeVersionInt32IsLinkInt16 IsDownloadInt16 IsNotBounceInt16FUniqIDInt64%œlû©+k:¤ìWëÂm OriginalURLStringHIDInt32 IsOldCounterInt16IsEventInt16 IsParameterInt16 DontCountHitsInt16WithHashInt16HitColorString5555555555LocalEventTimeDateTime&·ãQǘãQ}žãQÝžãQ'¡ãQA¶ãQ¼£ãQ ¦ãQY’ãQ‹ÏãQAgeInt16SexInt16IncomeInt16 InterestsInt16¦: RobotnessInt16RemoteIPInt32^DIÄ^DIÄ^DIÄ^DIÄ9ê3N^DIÄ…U…U€=k^DIÄ WindowNameInt32ÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿ OpenerNameInt32ÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿ HistoryLengthInt16ÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿBrowserLanguageString����������BrowserCountryString� � � � � � � � � � SocialNetworkString SocialActionString HTTPErrorInt16 SendTimingInt32 DNSTimingInt32 ConnectTimingInt32ResponseStartTimingInt32ResponseEndTimingInt32 FetchTimingInt32SocialSourceNetworkIDInt16SocialSourcePageString ParamPriceInt64 ParamOrderIDString ParamCurrencyStringNHNHNHNHNHNHNHNHNHNHParamCurrencyIDInt16OpenstatServiceNameStringOpenstatCampaignIDString OpenstatAdIDStringOpenstatSourceIDString UTMSourceString UTMMediumString UTMCampaignString UTMContentStringUTMTermStringFromTagStringHasGCLIDInt16 RefererHashInt64X+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûX+‚Œ'ÕãûURLHashInt64Í|3úÐb.‹Í|3úÐb.‹Í|3úÐb.‹Í|3úÐb.‹Ž oâïòeý€ à#â\X-h³ýX vÀvÍÀ‰Çh˜´9›DÍ|3úÐb.‹CLIDInt32$$);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000008889ea6 4. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:167: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000001702fa34 5. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000001702df6f 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f58c32 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::NativeReader::read() @ 0x000000001a293bda 8. ./build_docker/./src/Processors/Formats/Impl/NativeFormat.cpp:41: DB::NativeInputFormat::read() @ 0x000000001a4da786 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001a311955 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2e13d5 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a30a201 17. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015eb7f79 18. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 19. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 29. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 2025.10.24 00:02:26.547895 [ 3875 ] {18e2dc52-93ce-4225-9742-f7a2ca1d1e05} TCPHandler: Code: 131. DB::Exception: Too large string size: 18446744073709551615. The maximum is: 17179869184.: While executing Native. (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000008889ea6 4. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:167: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000001702fa34 5. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000001702df6f 6. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f58c32 7. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:202: DB::NativeReader::read() @ 0x000000001a293bda 8. ./build_docker/./src/Processors/Formats/Impl/NativeFormat.cpp:41: DB::NativeInputFormat::read() @ 0x000000001a4da786 9. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001a311955 10. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2e13d5 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 15. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a30a201 17. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015eb7f79 18. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 19. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 29. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 2025.10.24 00:02:27.689138 [ 3511 ] {} ExternalDictionariesLoader: Could not update external dictionary '36ef1abc-abab-4f85-93c6-36b673161500', leaving the previous version, next update is scheduled at 2025-10-24 00:02:33: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=2): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9bdbb2 16. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a967e00 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 23. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe 24. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a30a201 25. ./build_docker/./src/Dictionaries/DictionaryPipelineExecutor.cpp:0: DB::DictionaryPipelineExecutor::pull(DB::Block&) @ 0x000000000ff54611 26. DB::FlatDictionary::loadData() @ 0x000000000ff59b6b 27. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000ff592e0 28. std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration const&, std::shared_ptr const&, void>(std::allocator const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::FlatDictionary::Configuration const&, std::shared_ptr const&) @ 0x000000000ff8e02b 29. DB::FlatDictionary::clone() const @ 0x000000000ff81967 30. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1519: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x0000000017be631f 31. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000017be1eb1 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:28.313214 [ 3322 ] {} 65b6cb1a-c1ff-445d-85b5-d8acc2583ba0::0_0_1_1 (MergeFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001996532a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d44b94 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d433a9 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 31. __tsan_thread_start_func @ 0x000000000758df2f (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:28.314175 [ 3322 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {65b6cb1a-c1ff-445d-85b5-d8acc2583ba0::0_0_1_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./src/Storages/MergeTree/MergeFromLogEntryTask.h:36: DB::MergeFromLogEntryTask::executeInnerTask() @ 0x000000001996532a 21. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x0000000019d44b94 22. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000019d433a9 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 31. __tsan_thread_start_func @ 0x000000000758df2f (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:28.880988 [ 21804 ] {dd28c698-0ce6-4c1d-ab15-a7ae4f54de9b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=751). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:51100) (comment: 00149_quantiles_timing_distributed.sql) (in query: SELECT `__table1`.`CounterID` AS `CounterID`, quantileTiming(0.5)(`__table1`.`SendTiming`) AS `quantileTiming(0.5)(SendTiming)`, count() AS `count()` FROM `test`.`hits` AS `__table1` WHERE `__table1`.`SendTiming` != -1 GROUP BY `__table1`.`CounterID`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:02:28.882629 [ 21804 ] {dd28c698-0ce6-4c1d-ab15-a7ae4f54de9b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=751). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:02:28.930222 [ 22390 ] {e26c0ec1-6c2f-4ed3-a2bf-3486db30b0a1} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.9:9000. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=751). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:58138) (comment: 00149_quantiles_timing_distributed.sql) (in query: SELECT sum(cityHash64(*)) FROM (SELECT CounterID, quantileTiming(0.5)(SendTiming), count() FROM remote('127.0.0.{1,2,3,4,5,6,7,8,9,10}', test.hits) WHERE SendTiming != -1 GROUP BY CounterID);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000faa1a74 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a058f02 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a063254 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0c20fe 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e35bdf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e356e0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e34243 2025.10.24 00:02:28.942072 [ 21676 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:37214, local: [::ffff:127.0.0.4]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe5aed 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fbe4c7d 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fbe52f4 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:0: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a06adcf 6. DB::ReadBuffer::next() @ 0x0000000007b3717b 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001a1eb31a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:28.945202 [ 21658 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:48072, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe5aed 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fbe4c7d 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:0: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fbe52f4 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:0: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a06adcf 6. DB::ReadBuffer::next() @ 0x0000000007b3717b 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000001a1eb31a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:28.945560 [ 22390 ] {e26c0ec1-6c2f-4ed3-a2bf-3486db30b0a1} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.9:9000. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=751). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000faa1a74 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a058f02 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a063254 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0c20fe 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e35bdf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e356e0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e34243 2025.10.24 00:02:29.245076 [ 21893 ] {da272c24-f3ea-4973-968d-3ed88474b166} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:50216). (NETWORK_ERROR) (version 24.8.14.10544.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:50216) (comment: 00149_quantiles_timing_distributed.sql) (in query: SELECT `__table1`.`CounterID` AS `CounterID`, quantileTiming(0.5)(`__table1`.`SendTiming`) AS `quantileTiming(0.5)(SendTiming)`, count() AS `count()` FROM `test`.`hits` AS `__table1` WHERE `__table1`.`SendTiming` != -1 GROUP BY `__table1`.`CounterID`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe5aed 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe7532 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a06e78e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000001a1fafe5 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec2c2 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.24 00:02:29.247414 [ 21893 ] {da272c24-f3ea-4973-968d-3ed88474b166} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:50216). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe5aed 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe76f0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a06e78e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000001a20b607 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000001a1fabfc 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec459 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:29.247827 [ 21893 ] {da272c24-f3ea-4973-968d-3ed88474b166} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:50216). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe5aed 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe7532 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a06e78e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000001a1fafe5 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec2c2 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.24 00:02:29.248641 [ 21893 ] {da272c24-f3ea-4973-968d-3ed88474b166} TCPHandler: Client has gone away. 2025.10.24 00:02:29.446497 [ 21666 ] {fcb8819b-8f92-4faf-bcb2-fc2aa39dad68} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:47836). (NETWORK_ERROR) (version 24.8.14.10544.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:47836) (comment: 00149_quantiles_timing_distributed.sql) (in query: SELECT `__table1`.`CounterID` AS `CounterID`, quantileTiming(0.5)(`__table1`.`SendTiming`) AS `quantileTiming(0.5)(SendTiming)`, count() AS `count()` FROM `test`.`hits` AS `__table1` WHERE `__table1`.`SendTiming` != -1 GROUP BY `__table1`.`CounterID`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe5aed 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe76f0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a06e78e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000001a2002c3 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f9728 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 2025.10.24 00:02:29.449427 [ 21666 ] {fcb8819b-8f92-4faf-bcb2-fc2aa39dad68} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:47836). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe5aed 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe76f0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a06e78e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000001a20b607 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000001a1fabfc 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec459 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:29.449805 [ 21666 ] {fcb8819b-8f92-4faf-bcb2-fc2aa39dad68} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:47836). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fbe5aed 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:0: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fbe76f0 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:127: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000001a06e78e 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000001a2002c3 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f9728 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 14. __tsan_thread_start_func @ 0x000000000758df2f 15. ? @ 0x00007f7c69445ac3 16. ? @ 0x00007f7c694d7850 2025.10.24 00:02:29.450559 [ 21666 ] {fcb8819b-8f92-4faf-bcb2-fc2aa39dad68} TCPHandler: Client has gone away. 2025.10.24 00:02:29.692164 [ 22390 ] {ad73bc80-2e47-48c1-b253-38a0b1353434} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:41434) (comment: 00143_transform_non_const_default.sql) (in query: SELECT transform(SearchEngineID, [2, 3], ['ЯндекÑ', 'Google'], PageCharset) AS title, count() AS c FROM test.hits WHERE SearchEngineID != 0 GROUP BY title HAVING c > 0 ORDER BY c DESC LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.24 00:02:29.694330 [ 22390 ] {ad73bc80-2e47-48c1-b253-38a0b1353434} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.24 00:02:30.939993 [ 21833 ] {bf2d17d7-cce0-4c94-84d8-0ea1a0d3193a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=748). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:41466) (comment: 01375_storage_file_write_prefix_tsv_with_names.sql) (in query: INSERT INTO table_tsv_01375 SELECT number as n, toString(n) as s FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f2d53 8. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000001a1ec1ec 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.24 00:02:30.944609 [ 21833 ] {bf2d17d7-cce0-4c94-84d8-0ea1a0d3193a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=748). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f2d53 8. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000001a1ec1ec 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.24 00:02:31.072172 [ 2700 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:35.986748 [ 3308 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {678af7ec-371a-476f-b893-c6848743a362::202510_1_110_22}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:38.088103 [ 2703 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:38.808441 [ 21762 ] {e9c1d2ae-d8b6-49e5-9d1b-1df5367cdeb3} executeQuery: Code: 36. DB::Exception: Query tree is too big. Maximum: 500000. (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:41640) (comment: 00596_limit_on_expanded_ast.sh) (in query: select 1 as a, a+a as b, b+b as c, c+c as d, d+d as e, e+e as f, f+f as g, g+g as h, h+h as i, i+i as j, j+j as k, k+k as l, l+l as m, m+m as n, n+n as o, o+o as p, p+p as q, q+q as r, r+r as s, s+s as t, t+t as u, u+u as v, v+v as w, w+w as x, x+x as y, y+y as z ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000008222800 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:471: DB::validateTreeSize(std::shared_ptr const&, unsigned long, std::unordered_map, unsigned long, std::hash>, std::equal_to>, std::allocator const, unsigned long>>>&) @ 0x00000000175148ce 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a33e3 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.24 00:02:38.810653 [ 21762 ] {e9c1d2ae-d8b6-49e5-9d1b-1df5367cdeb3} TCPHandler: Code: 36. DB::Exception: Query tree is too big. Maximum: 500000. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x0000000008222800 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:471: DB::validateTreeSize(std::shared_ptr const&, unsigned long, std::unordered_map, unsigned long, std::hash>, std::equal_to>, std::allocator const, unsigned long>>>&) @ 0x00000000175148ce 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a33e3 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.24 00:02:39.091354 [ 2700 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:40.094366 [ 2697 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:41.866510 [ 21696 ] {32cc0d93-e028-4452-811a-bc23cdd88de1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=747). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:33770) (comment: 02158_explain_ast_alter_commands.sh) (in query: EXPLAIN AST ALTER TABLE t DELETE IN PARTITION 'p' WHERE c = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:02:41.867061 [ 21696 ] {32cc0d93-e028-4452-811a-bc23cdd88de1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=747). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:02:44.745680 [ 8857 ] {027ff733-fd8c-4511-a724-a1d524d9e893} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a51c47d 8. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000001a51a56c 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001a51fc30 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001a51fae2 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:44.750126 [ 22371 ] {027ff733-fd8c-4511-a724-a1d524d9e893} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): (in file/uri /var/lib/clickhouse/user_files/test_13/lz4_compression.lz4): While executing ParallelParsingBlockInputFormat: While executing File. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:33814) (comment: 02012_compress_lz4.sh) (in query: SELECT * FROM file('/var/lib/clickhouse/user_files/test_13/lz4_compression.lz4', 'TabSeparated', 'col String')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a51c47d 8. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000001a51a56c 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001a51fc30 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001a51fae2 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.24 00:02:44.754425 [ 22371 ] {027ff733-fd8c-4511-a724-a1d524d9e893} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): (in file/uri /var/lib/clickhouse/user_files/test_13/lz4_compression.lz4): While executing ParallelParsingBlockInputFormat: While executing File. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a51c47d 8. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000001a51a56c 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001a51fc30 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001a51fae2 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.24 00:02:45.179102 [ 21666 ] {304df0fc-b268-4674-af6b-38e531d863bb} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:33812) (comment: 00041_aggregating_materialized_view.sql) (in query: DROP TABLE test.visits_null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1e9f1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c766aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c74615 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c739c9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:02:45.180809 [ 21666 ] {304df0fc-b268-4674-af6b-38e531d863bb} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1e9f1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c766aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c74615 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c739c9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:02:46.001365 [ 10931 ] {e6db1a5b-0c49-47ce-ab91-81415ec58fd1} executeQuery: Code: 410. DB::Exception: BridgeHelper: clickhouse-odbc-bridge is not responding. (EXTERNAL_SERVER_IS_NOT_RESPONDING) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47708) (comment: 01086_odbc_roundtrip.sh) (in query: select count() > 1 as ok from (select * from odbc('DSN={ClickHouse DSN (ANSI)}','system','tables'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/BridgeHelper/IBridgeHelper.cpp:0: DB::IBridgeHelper::startBridgeSync() @ 0x000000001a0d9a59 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::ITableFunctionXDBC::startBridgeIfNot(std::shared_ptr) const @ 0x0000000015ea5d74 6. ./build_docker/./src/TableFunctions/ITableFunctionXDBC.cpp:0: DB::(anonymous namespace)::ITableFunctionXDBC::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015ea567d 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 8. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1bbd 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d690b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:02:46.004124 [ 10931 ] {e6db1a5b-0c49-47ce-ab91-81415ec58fd1} TCPHandler: Code: 410. DB::Exception: BridgeHelper: clickhouse-odbc-bridge is not responding. (EXTERNAL_SERVER_IS_NOT_RESPONDING), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/BridgeHelper/IBridgeHelper.cpp:0: DB::IBridgeHelper::startBridgeSync() @ 0x000000001a0d9a59 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::ITableFunctionXDBC::startBridgeIfNot(std::shared_ptr) const @ 0x0000000015ea5d74 6. ./build_docker/./src/TableFunctions/ITableFunctionXDBC.cpp:0: DB::(anonymous namespace)::ITableFunctionXDBC::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015ea567d 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 8. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1bbd 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d690b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:02:47.361627 [ 11323 ] {} ExternalDictionariesLoader: Could not update external dictionary '36ef1abc-abab-4f85-93c6-36b673161500', leaving the previous version, next update is scheduled at 2025-10-24 00:02:53: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019afcfca 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001a947c35 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a94638f 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1454: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a946030 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1934: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9507fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8f5f22 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9210b9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dc3569 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017dc3210 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000000fe64c6e 19. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:115: DB::ClickHouseDictionarySource::loadAll() @ 0x000000000fe64b68 20. DB::FlatDictionary::loadData() @ 0x000000000ff59b00 21. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000ff592e0 22. std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration const&, std::shared_ptr const&, void>(std::allocator const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::FlatDictionary::Configuration const&, std::shared_ptr const&) @ 0x000000000ff8e02b 23. DB::FlatDictionary::clone() const @ 0x000000000ff81967 24. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1519: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x0000000017be631f 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000017be1eb1 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000017bea528 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000017bea322 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 30. __tsan_thread_start_func @ 0x000000000758df2f 31. ? @ 0x00007f7c69445ac3 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:50.043538 [ 21666 ] {6271c5c2-6898-4608-a91f-52422a05a457} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:51490) (comment: 01825_type_json_5.sql) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:02:50.044700 [ 21666 ] {6271c5c2-6898-4608-a91f-52422a05a457} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000ad8cd20 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x000000001682a990 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000016829f42 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x000000001682a203 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000175b65d6 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000017e4dc8c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:02:50.124557 [ 2709 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:50.381852 [ 2707 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:51.018529 [ 2841 ] {} RefreshTask: Refresh view test_13.e failed (attempt 1/1): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 15. ./src/Interpreters/InterpreterCreateQuery.h:29: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x0000000017c5085a 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1535: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4da81 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 18. ./build_docker/./src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x00000000192bab92 19. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:380: DB::RefreshTask::executeRefreshUnlocked(bool) @ 0x0000000019ff6028 20. ./contrib/llvm-project/libcxx/include/__mutex_base:207: DB::RefreshTask::refreshTask() @ 0x0000000019ff46e8 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019ff7522 22. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 24. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:51.383733 [ 22061 ] {1bee304b-8b1c-4114-b2b7-0c63279608ba} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=747). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:51506) (comment: 00061_storage_buffer.sql) (in query: SELECT count() FROM test.hits_dst;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:02:51.384926 [ 22061 ] {1bee304b-8b1c-4114-b2b7-0c63279608ba} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=747). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:02:52.930743 [ 8859 ] {} ExternalDictionariesLoader: Could not update external dictionary '4d942a90-5124-4d50-8e84-011027e2fc87', leaving the previous version, next update is scheduled at 2025-10-24 00:02:57: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bfc297 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000019bfd21f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000017028d42 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f581e4 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019bf9bd6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bf97d5 16. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x0000000019abec34 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aba072 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c63e3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a30a201 30. ./build_docker/./src/Dictionaries/DictionaryPipelineExecutor.cpp:0: DB::DictionaryPipelineExecutor::pull(DB::Block&) @ 0x000000000ff54611 31. DB::FlatDictionary::loadData() @ 0x000000000ff59b6b (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:53.166572 [ 2702 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:54.020718 [ 2750 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:55.170679 [ 2698 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:57.188698 [ 2711 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:57.267078 [ 21666 ] {89f42fc0-b0e6-4dec-97ea-0e25aca9837e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:51582) (comment: 01213_alter_rename_column_zookeeper_long.sh) (in query: CREATE TABLE table_for_rename_replicated ( date Date, key UInt64, value1 String, value2 String, value3 String ) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01213_alter_rename_column_zookeeper_long_test_13/table_for_rename_replicated', '1') PARTITION BY date ORDER BY key;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000019341fd0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000019e4f587 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a2e3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 2025.10.24 00:02:57.270150 [ 21666 ] {89f42fc0-b0e6-4dec-97ea-0e25aca9837e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000019341fd0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000019e4f587 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a2e3 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 2025.10.24 00:02:57.768185 [ 21666 ] {3d339f9c-946f-4d0f-a2fe-e0154d33c2e2} executeQuery: Code: 60. DB::Exception: Table test_13.table_for_rename_replicated does not exist. (UNKNOWN_TABLE) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:51626) (comment: 01213_alter_rename_column_zookeeper_long.sh) (in query: INSERT INTO table_for_rename_replicated SELECT toDate('2019-10-01') + number % 3, number, toString(number), toString(number), toString(number) from numbers(9);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017141363 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000017697dc1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001769f180 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d45ccf 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f0da 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:02:57.770916 [ 21666 ] {3d339f9c-946f-4d0f-a2fe-e0154d33c2e2} TCPHandler: Code: 60. DB::Exception: Table test_13.table_for_rename_replicated does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000017141363 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000017697dc1 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001769f180 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x0000000017d45ccf 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f0da 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:02:58.192791 [ 2707 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:02:58.275664 [ 22061 ] {7c1c4da1-4c18-4360-ad92-6f80115d6447} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'table_for_rename_replicated' in scope SELECT value1 FROM table_for_rename_replicated WHERE key = 1. (UNKNOWN_TABLE) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:51646) (comment: 01213_alter_rename_column_zookeeper_long.sh) (in query: SELECT value1 FROM table_for_rename_replicated WHERE key = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d594c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996bc 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 2025.10.24 00:02:58.277731 [ 22061 ] {7c1c4da1-4c18-4360-ad92-6f80115d6447} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'table_for_rename_replicated' in scope SELECT value1 FROM table_for_rename_replicated WHERE key = 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d594c 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996bc 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 2025.10.24 00:02:59.288168 [ 21666 ] {9a1f41e5-c4c1-457c-8b80-f6442f51ec76} executeQuery: Code: 390. DB::Exception: Table `table_for_rename_replicated` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57690) (comment: 01213_alter_rename_column_zookeeper_long.sh) (in query: SHOW CREATE TABLE table_for_rename_replicated;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x00000000170a2285 5. ./src/Databases/IDatabase.h:396: DB::InterpreterShowCreateQuery::executeImpl() @ 0x000000001828bd05 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x000000001828b7bf 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.24 00:02:59.290029 [ 21666 ] {9a1f41e5-c4c1-457c-8b80-f6442f51ec76} TCPHandler: Code: 390. DB::Exception: Table `table_for_rename_replicated` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x00000000170a2285 5. ./src/Databases/IDatabase.h:396: DB::InterpreterShowCreateQuery::executeImpl() @ 0x000000001828bd05 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x000000001828b7bf 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.24 00:02:59.799593 [ 21666 ] {1948bd35-c00c-4275-930e-61886dc49373} executeQuery: Code: 60. DB::Exception: Could not find table: table_for_rename_replicated. (UNKNOWN_TABLE) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57706) (comment: 01213_alter_rename_column_zookeeper_long.sh) (in query: ALTER TABLE table_for_rename_replicated RENAME COLUMN value1 to renamed_value1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2a671 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.24 00:02:59.801268 [ 21666 ] {1948bd35-c00c-4275-930e-61886dc49373} TCPHandler: Code: 60. DB::Exception: Could not find table: table_for_rename_replicated. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c2a671 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.24 00:03:03.016314 [ 21666 ] {0d61e9ff-a1cf-4474-8f6c-919be3c20904} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test.hits, because some tables depend on it: db_dict.cache_hits. (HAVE_DEPENDENT_OBJECTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57782) (comment: 00140_rename.sql) (in query: RENAME TABLE test.hits TO test.visits_tmp, test.visits TO test.hits, test.visits_tmp TO test.visits;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000176b4606 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1543: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000176ab34d 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1503: DB::DatabaseCatalog::removeDependencies(DB::StorageID const&, bool, bool, bool) @ 0x00000000176aadd2 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000017d5b590 7. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000017d59e84 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:03:03.018859 [ 21666 ] {0d61e9ff-a1cf-4474-8f6c-919be3c20904} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test.hits, because some tables depend on it: db_dict.cache_hits. (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000176b4606 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1543: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000176ab34d 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1503: DB::DatabaseCatalog::removeDependencies(DB::StorageID const&, bool, bool, bool) @ 0x00000000176aadd2 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000017d5b590 7. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::InterpreterRenameQuery::execute() @ 0x0000000017d59e84 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:03:05.333735 [ 2711 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:03:09.403126 [ 22061 ] {f1756abc-ba0f-4d23-aef6-39abe33ed2f6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:41122) (comment: 00008_uniq.sql) (in query: SELECT uniq(UserID), uniqIf(UserID, CounterID = 800784), uniqIf(FUniqID, RegionID = 213) FROM test.hits ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.24 00:03:09.406659 [ 22061 ] {f1756abc-ba0f-4d23-aef6-39abe33ed2f6} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.24 00:03:11.345523 [ 2698 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:03:12.347905 [ 2699 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:03:14.093415 [ 22188 ] {0bb0c341-aa14-4c50-a173-68f270d27515} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:41252) (comment: 00056_view.sql) (in query: SELECT * FROM test.view ORDER BY c DESC LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.24 00:03:14.096032 [ 22188 ] {0bb0c341-aa14-4c50-a173-68f270d27515} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.24 00:03:15.154005 [ 18285 ] {ffe9dcea-b258-4de6-b262-781d9612933d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:41290) (comment: 00351_select_distinct_arrays_tuples.sql) (in query: SELECT count(), count(DISTINCT x, y) FROM (SELECT DISTINCT * FROM (SELECT [1, 2] AS x, [3] AS y UNION ALL SELECT [1], [2, 3]));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.24 00:03:15.156346 [ 18285 ] {ffe9dcea-b258-4de6-b262-781d9612933d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.24 00:03:15.353853 [ 2708 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:03:16.278379 [ 22188 ] {210e7df5-c70c-4d21-8190-374e21426573} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:41318) (comment: 00174_distinct_in_order.sql) (in query: select distinct * from distinct_in_order except select * from ordinary_distinct;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.24 00:03:16.279904 [ 22188 ] {210e7df5-c70c-4d21-8190-374e21426573} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 2025.10.24 00:03:21.368746 [ 2711 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:03:25.379938 [ 2702 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:03:27.386320 [ 2698 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:03:33.568863 [ 22188 ] {80f0c3cb-63e9-43aa-ac9b-8210c853f9cd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:58672) (comment: 02125_lz4_compression_bug_JSONEachRow.sh) (in query: INSERT INTO file SELECT * FROM numbers(1000000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a518951 8. ./contrib/llvm-project/libcxx/include/atomic:1009: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000001a517265 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000001a51941d 10. ./contrib/llvm-project/libcxx/include/vector:438: DB::IOutputFormat::write(DB::Block const&) @ 0x000000001a315796 11. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::StorageFileSink::consume(DB::Chunk&) @ 0x00000000191ee39a 12. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7de8ed 13. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a6a6806 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6a6578 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a6a5e75 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 20. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f356a 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 23. __tsan_thread_start_func @ 0x000000000758df2f 24. ? @ 0x00007f7c69445ac3 25. ? @ 0x00007f7c694d7850 2025.10.24 00:03:33.574250 [ 22188 ] {80f0c3cb-63e9-43aa-ac9b-8210c853f9cd} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a518951 8. ./contrib/llvm-project/libcxx/include/atomic:1009: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x000000001a517265 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x000000001a51941d 10. ./contrib/llvm-project/libcxx/include/vector:438: DB::IOutputFormat::write(DB::Block const&) @ 0x000000001a315796 11. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::StorageFileSink::consume(DB::Chunk&) @ 0x00000000191ee39a 12. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7de8ed 13. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a6a6806 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6a6578 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a6a5e75 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 20. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a2f356a 21. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 23. __tsan_thread_start_func @ 0x000000000758df2f 24. ? @ 0x00007f7c69445ac3 25. ? @ 0x00007f7c694d7850 2025.10.24 00:03:39.444708 [ 2708 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:03:43.099858 [ 2836 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:03:44.457150 [ 2699 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:03:45.460960 [ 2711 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:03:46.463536 [ 2707 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x00000000195f7262 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000195f8502 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:03:47.959491 [ 8859 ] {} ExternalDictionariesLoader: Could not update external dictionary '36ef1abc-abab-4f85-93c6-36b673161500', leaving the previous version, next update is scheduled at 2025-10-24 00:03:53: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019afcfca 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, DB::MergeTreeData const&, std::vector> const&, std::shared_ptr, std::optional&, bool) @ 0x000000001a947c35 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000001a94638f 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1454: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000001a946030 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1934: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9507fa 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000001a8f5f22 13. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:188: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000001a9210b9 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000017dc3569 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000017dc3210 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 18. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000000fe64c6e 19. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:115: DB::ClickHouseDictionarySource::loadAll() @ 0x000000000fe64b68 20. DB::FlatDictionary::loadData() @ 0x000000000ff59b00 21. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000000ff592e0 22. std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration const&, std::shared_ptr const&, void>(std::allocator const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::FlatDictionary::Configuration const&, std::shared_ptr const&) @ 0x000000000ff8e02b 23. DB::FlatDictionary::clone() const @ 0x000000000ff81967 24. ./build_docker/./src/Interpreters/ExternalLoader.cpp:1519: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x0000000017be631f 25. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x0000000017be1eb1 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x0000000017bea528 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000017bea322 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 30. __tsan_thread_start_func @ 0x000000000758df2f 31. ? @ 0x00007f7c69445ac3 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:03:52.723400 [ 3513 ] {} ExternalDictionariesLoader: Could not update external dictionary '4d942a90-5124-4d50-8e84-011027e2fc87', leaving the previous version, next update is scheduled at 2025-10-24 00:03:57: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=0): (while reading column fourth_column): (while reading from part /var/lib/clickhouse/store/847/8471dccc-d02b-4a9b-be32-a2c153b48d95/all_1_1_0/ in table database_for_dict.table_for_dict (8471dccc-d02b-4a9b-be32-a2c153b48d95) located on disk default of type local, from mark 0 with max_rows_to_read = 100): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d62f83 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d65385 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d655fe 16. DB::ReadBuffer::next() @ 0x0000000007b3717b 17. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:85: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000001702b2e9 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x0000000019bfbc4a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bfb20e 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a98c8ea 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 27. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 28. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:03:56.342080 [ 18285 ] {712329b3-a935-48f9-8e63-b7bd149923f8} executeQuery: Code: 57. DB::Exception: Table test_1.t_move_to_prewhere already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:42928) (comment: 01824_move_to_prewhere_many_columns.sql) (in query: -- With only compact parts, we cannot move 3 conditions to PREWHERE, -- because we don't know sizes and we can use only number of columns in conditions. -- Sometimes moving a lot of columns to prewhere may be harmful. CREATE TABLE t_move_to_prewhere (id UInt32, a UInt8, b UInt8, c UInt8, fat_string String) ENGINE = MergeTree ORDER BY id PARTITION BY id SETTINGS min_rows_for_wide_part = 10000, min_bytes_for_wide_part = 100000000;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.24 00:03:56.344012 [ 18285 ] {712329b3-a935-48f9-8e63-b7bd149923f8} TCPHandler: Code: 57. DB::Exception: Table test_1.t_move_to_prewhere already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.24 00:04:00.976310 [ 18285 ] {ae5622a6-8638-4336-9842-ad5252f40560} BackupsWorker: Failed to make backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]'): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016921080 9. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::buildFileInfosForBackupEntries(std::shared_ptr const&, std::vector>, std::allocator>>> const&, DB::ReadSettings const&, std::shared_ptr, std::shared_ptr) @ 0x00000000168c0495 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:606: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168be4f8 11. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b9a3e 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b905a 13. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 23. __tsan_thread_start_func @ 0x000000000758df2f 24. ? @ 0x00007f7c69445ac3 25. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:04:01.039124 [ 18285 ] {ae5622a6-8638-4336-9842-ad5252f40560} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50772) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: BACKUP TABLE data TO S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') SETTINGS base_backup = S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_base', 'test', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016921080 9. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::buildFileInfosForBackupEntries(std::shared_ptr const&, std::vector>, std::allocator>>> const&, DB::ReadSettings const&, std::shared_ptr, std::shared_ptr) @ 0x00000000168c0495 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:606: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168be4f8 11. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b9a3e 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b905a 13. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 23. __tsan_thread_start_func @ 0x000000000758df2f 24. ? @ 0x00007f7c69445ac3 25. ? @ 0x00007f7c694d7850 2025.10.24 00:04:01.040486 [ 18285 ] {ae5622a6-8638-4336-9842-ad5252f40560} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016921080 9. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::buildFileInfosForBackupEntries(std::shared_ptr const&, std::vector>, std::allocator>>> const&, DB::ReadSettings const&, std::shared_ptr, std::shared_ptr) @ 0x00000000168c0495 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:606: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168be4f8 11. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b9a3e 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b905a 13. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 23. __tsan_thread_start_func @ 0x000000000758df2f 24. ? @ 0x00007f7c69445ac3 25. ? @ 0x00007f7c694d7850 2025.10.24 00:04:02.004208 [ 18285 ] {c9885024-8d0f-4504-ae48-7d0eaa94acef} executeQuery: Code: 499. DB::Exception: Failed to get object info: No response body.. HTTP response code: 404: while reading backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1/.backup: While executing S3Source. (S3_ERROR) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50782) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: SELECT replace(line, 'testtest', 'INVALID_PASSWORD') FROM s3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1/.backup', 'test', '[HIDDEN]', 'LineAsString')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::S3Exception::S3Exception(Aws::S3::S3Errors, fmt::v9::basic_format_string::type, fmt::v9::type_identity::type>, String const&, unsigned long&&) @ 0x00000000164975c1 3. ./build_docker/./src/IO/S3/getObjectInfo.cpp:87: DB::S3::getObjectInfo(DB::S3::Client const&, String const&, String const&, String const&, bool, bool) @ 0x0000000016497de0 4. ./build_docker/./src/Disks/ObjectStorages/S3/S3ObjectStorage.cpp:0: DB::S3ObjectStorage::getObjectMetadata(String const&) const @ 0x00000000164867e2 5. ./src/Disks/ObjectStorages/IObjectStorage.h:53: DB::StorageObjectStorageSource::KeysIterator::nextImpl(unsigned long) @ 0x000000001639310a 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:468: DB::StorageObjectStorageSource::IIterator::next(unsigned long) @ 0x000000001638e9b7 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:298: DB::StorageObjectStorageSource::createReader(unsigned long, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ReadFromFormatInfo&, std::optional const&, std::shared_ptr const&, std::shared_ptr const&, DB::SchemaCache*, std::shared_ptr const&, unsigned long, unsigned long, bool) @ 0x000000001638d88e 8. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:273: DB::StorageObjectStorageSource::createReader() @ 0x000000001638c2cb 9. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:167: DB::StorageObjectStorageSource::lazyInitialize() @ 0x000000001638c006 10. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:0: DB::StorageObjectStorageSource::generate() @ 0x000000001638c690 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2e13d5 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.24 00:04:02.006143 [ 18285 ] {c9885024-8d0f-4504-ae48-7d0eaa94acef} TCPHandler: Code: 499. DB::Exception: Failed to get object info: No response body.. HTTP response code: 404: while reading backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1/.backup: While executing S3Source. (S3_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::S3Exception::S3Exception(Aws::S3::S3Errors, fmt::v9::basic_format_string::type, fmt::v9::type_identity::type>, String const&, unsigned long&&) @ 0x00000000164975c1 3. ./build_docker/./src/IO/S3/getObjectInfo.cpp:87: DB::S3::getObjectInfo(DB::S3::Client const&, String const&, String const&, String const&, bool, bool) @ 0x0000000016497de0 4. ./build_docker/./src/Disks/ObjectStorages/S3/S3ObjectStorage.cpp:0: DB::S3ObjectStorage::getObjectMetadata(String const&) const @ 0x00000000164867e2 5. ./src/Disks/ObjectStorages/IObjectStorage.h:53: DB::StorageObjectStorageSource::KeysIterator::nextImpl(unsigned long) @ 0x000000001639310a 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:468: DB::StorageObjectStorageSource::IIterator::next(unsigned long) @ 0x000000001638e9b7 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:298: DB::StorageObjectStorageSource::createReader(unsigned long, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::ReadFromFormatInfo&, std::optional const&, std::shared_ptr const&, std::shared_ptr const&, DB::SchemaCache*, std::shared_ptr const&, unsigned long, unsigned long, bool) @ 0x000000001638d88e 8. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:273: DB::StorageObjectStorageSource::createReader() @ 0x000000001638c2cb 9. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:167: DB::StorageObjectStorageSource::lazyInitialize() @ 0x000000001638c006 10. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:0: DB::StorageObjectStorageSource::generate() @ 0x000000001638c690 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2e13d5 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.24 00:04:03.280542 [ 18285 ] {3b8f68d4-97f8-49ea-a1a1-e00980cb7edc} BackupsWorker: Failed to make backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_2', 'test', '[HIDDEN]'): Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x000000001697e6c3 5. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016979b18 6. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000016978ecc 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995d79 8. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 9. ./build_docker/./src/Backups/BackupImpl.cpp:271: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001697f2e2 10. ./build_docker/./src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x0000000016979b4f 11. ./build_docker/./src/Backups/BackupImpl.cpp:145: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x000000001697a667 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995a66 13. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 14. ./build_docker/./src/Backups/BackupsWorker.cpp:609: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168be002 15. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b9a3e 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b905a 17. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:04:03.282222 [ 18285 ] {3b8f68d4-97f8-49ea-a1a1-e00980cb7edc} executeQuery: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50802) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: BACKUP TABLE data TO S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_2', 'test', '[HIDDEN]') SETTINGS base_backup = S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x000000001697e6c3 5. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016979b18 6. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000016978ecc 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995d79 8. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 9. ./build_docker/./src/Backups/BackupImpl.cpp:271: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001697f2e2 10. ./build_docker/./src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x0000000016979b4f 11. ./build_docker/./src/Backups/BackupImpl.cpp:145: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x000000001697a667 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995a66 13. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 14. ./build_docker/./src/Backups/BackupsWorker.cpp:609: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168be002 15. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b9a3e 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b905a 17. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.24 00:04:03.284993 [ 18285 ] {3b8f68d4-97f8-49ea-a1a1-e00980cb7edc} TCPHandler: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x000000001697e6c3 5. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016979b18 6. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000016978ecc 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995d79 8. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 9. ./build_docker/./src/Backups/BackupImpl.cpp:271: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001697f2e2 10. ./build_docker/./src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x0000000016979b4f 11. ./build_docker/./src/Backups/BackupImpl.cpp:145: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x000000001697a667 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995a66 13. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 14. ./build_docker/./src/Backups/BackupsWorker.cpp:609: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168be002 15. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b9a3e 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b905a 17. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.24 00:04:04.432583 [ 18285 ] {be2c5691-60a8-433e-a31b-cb9d0effe9a5} BackupsWorker: Failed to make backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_3_bad', 'test', '[HIDDEN]'): Code: 499. DB::Exception: The request signature we calculated does not match the signature you provided. Check your key and signing method. (S3_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::S3Exception::S3Exception(String const&, Aws::S3::S3Errors) @ 0x0000000016497441 3. ./build_docker/./src/Backups/BackupIO_S3.cpp:107: DB::(anonymous namespace)::listObjects(DB::S3::Client&, DB::S3::URI const&, String const&) @ 0x0000000016998cf6 4. ./build_docker/./src/Backups/BackupIO_S3.cpp:0: DB::BackupReaderS3::fileExists(String const&) @ 0x0000000016998845 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::BackupImpl::readBackupMetadata() @ 0x000000001697c8a1 6. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016979b18 7. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000016978ecc 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995d79 9. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 10. ./build_docker/./src/Backups/BackupImpl.cpp:271: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001697f2e2 11. ./build_docker/./src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x0000000016979b4f 12. ./build_docker/./src/Backups/BackupImpl.cpp:145: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x000000001697a667 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995a66 14. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 15. ./build_docker/./src/Backups/BackupsWorker.cpp:609: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168be002 16. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b9a3e 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b905a 18. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 28. __tsan_thread_start_func @ 0x000000000758df2f 29. ? @ 0x00007f7c69445ac3 30. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:04:04.434094 [ 18285 ] {be2c5691-60a8-433e-a31b-cb9d0effe9a5} executeQuery: Code: 499. DB::Exception: The request signature we calculated does not match the signature you provided. Check your key and signing method. (S3_ERROR) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50818) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: BACKUP TABLE data TO S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_3_bad', 'test', '[HIDDEN]') SETTINGS base_backup = S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::S3Exception::S3Exception(String const&, Aws::S3::S3Errors) @ 0x0000000016497441 3. ./build_docker/./src/Backups/BackupIO_S3.cpp:107: DB::(anonymous namespace)::listObjects(DB::S3::Client&, DB::S3::URI const&, String const&) @ 0x0000000016998cf6 4. ./build_docker/./src/Backups/BackupIO_S3.cpp:0: DB::BackupReaderS3::fileExists(String const&) @ 0x0000000016998845 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::BackupImpl::readBackupMetadata() @ 0x000000001697c8a1 6. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016979b18 7. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000016978ecc 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995d79 9. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 10. ./build_docker/./src/Backups/BackupImpl.cpp:271: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001697f2e2 11. ./build_docker/./src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x0000000016979b4f 12. ./build_docker/./src/Backups/BackupImpl.cpp:145: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x000000001697a667 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995a66 14. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 15. ./build_docker/./src/Backups/BackupsWorker.cpp:609: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168be002 16. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b9a3e 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b905a 18. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 28. __tsan_thread_start_func @ 0x000000000758df2f 29. ? @ 0x00007f7c69445ac3 30. ? @ 0x00007f7c694d7850 2025.10.24 00:04:04.436007 [ 18285 ] {be2c5691-60a8-433e-a31b-cb9d0effe9a5} TCPHandler: Code: 499. DB::Exception: The request signature we calculated does not match the signature you provided. Check your key and signing method. (S3_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::S3Exception::S3Exception(String const&, Aws::S3::S3Errors) @ 0x0000000016497441 3. ./build_docker/./src/Backups/BackupIO_S3.cpp:107: DB::(anonymous namespace)::listObjects(DB::S3::Client&, DB::S3::URI const&, String const&) @ 0x0000000016998cf6 4. ./build_docker/./src/Backups/BackupIO_S3.cpp:0: DB::BackupReaderS3::fileExists(String const&) @ 0x0000000016998845 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::BackupImpl::readBackupMetadata() @ 0x000000001697c8a1 6. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016979b18 7. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000016978ecc 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995d79 9. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 10. ./build_docker/./src/Backups/BackupImpl.cpp:271: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001697f2e2 11. ./build_docker/./src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x0000000016979b4f 12. ./build_docker/./src/Backups/BackupImpl.cpp:145: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x000000001697a667 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995a66 14. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 15. ./build_docker/./src/Backups/BackupsWorker.cpp:609: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168be002 16. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b9a3e 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b905a 18. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 28. __tsan_thread_start_func @ 0x000000000758df2f 29. ? @ 0x00007f7c69445ac3 30. ? @ 0x00007f7c694d7850 2025.10.24 00:04:04.490622 [ 3319 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4e167706-dfb8-4318-8e40-8928b14b09ce::202510_1_166_33}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:04:05.163103 [ 3316 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4e167706-dfb8-4318-8e40-8928b14b09ce::202510_1_166_33}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:04:05.182724 [ 18285 ] {3d215cbf-e794-4b8a-918f-99fda23a973e} BackupsWorker: Failed to make backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_4', 'test', '[HIDDEN]'): Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x000000001697e6c3 5. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016979b18 6. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000016978ecc 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995d79 8. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 9. ./build_docker/./src/Backups/BackupImpl.cpp:271: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001697f2e2 10. ./build_docker/./src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x0000000016979b4f 11. ./build_docker/./src/Backups/BackupImpl.cpp:145: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x000000001697a667 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995a66 13. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 14. ./build_docker/./src/Backups/BackupsWorker.cpp:609: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168be002 15. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b9a3e 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b905a 17. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:04:05.184766 [ 18285 ] {3d215cbf-e794-4b8a-918f-99fda23a973e} executeQuery: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50830) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: BACKUP TABLE data TO S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_4', 'test', '[HIDDEN]') SETTINGS base_backup = S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]'), use_same_s3_credentials_for_base_backup = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x000000001697e6c3 5. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016979b18 6. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000016978ecc 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995d79 8. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 9. ./build_docker/./src/Backups/BackupImpl.cpp:271: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001697f2e2 10. ./build_docker/./src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x0000000016979b4f 11. ./build_docker/./src/Backups/BackupImpl.cpp:145: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x000000001697a667 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995a66 13. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 14. ./build_docker/./src/Backups/BackupsWorker.cpp:609: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168be002 15. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b9a3e 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b905a 17. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.24 00:04:05.186741 [ 18285 ] {3d215cbf-e794-4b8a-918f-99fda23a973e} TCPHandler: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x000000001697e6c3 5. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016979b18 6. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000016978ecc 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995d79 8. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 9. ./build_docker/./src/Backups/BackupImpl.cpp:271: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001697f2e2 10. ./build_docker/./src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x0000000016979b4f 11. ./build_docker/./src/Backups/BackupImpl.cpp:145: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x000000001697a667 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995a66 13. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 14. ./build_docker/./src/Backups/BackupsWorker.cpp:609: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168be002 15. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b9a3e 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b905a 17. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.24 00:04:05.983779 [ 18285 ] {4aacc77c-cfc1-4b39-b5b5-f3c5a0d47ef1} BackupsWorker: Failed to restore from backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]'): Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x000000001697e6c3 5. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016979b18 6. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000016978ecc 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995d79 8. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 9. ./build_docker/./src/Backups/BackupsWorker.cpp:932: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr) @ 0x00000000168c3a85 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startRestoring(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168bb180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b9010 12. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:04:05.984640 [ 18285 ] {4aacc77c-cfc1-4b39-b5b5-f3c5a0d47ef1} executeQuery: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50842) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: RESTORE TABLE data FROM S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x000000001697e6c3 5. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016979b18 6. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000016978ecc 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995d79 8. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 9. ./build_docker/./src/Backups/BackupsWorker.cpp:932: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr) @ 0x00000000168c3a85 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startRestoring(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168bb180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b9010 12. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 2025.10.24 00:04:05.985598 [ 18285 ] {4aacc77c-cfc1-4b39-b5b5-f3c5a0d47ef1} TCPHandler: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x000000001697e6c3 5. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016979b18 6. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000016978ecc 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995d79 8. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 9. ./build_docker/./src/Backups/BackupsWorker.cpp:932: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr) @ 0x00000000168c3a85 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startRestoring(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168bb180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b9010 12. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 2025.10.24 00:04:06.664893 [ 18285 ] {11c29d8a-8d9c-4df2-8ef7-b1e853bd0092} BackupsWorker: Failed to restore from backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]'): Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x000000001697e6c3 5. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016979b18 6. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000016978ecc 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995d79 8. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 9. ./build_docker/./src/Backups/BackupsWorker.cpp:932: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr) @ 0x00000000168c3a85 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startRestoring(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168bb180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b9010 12. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:04:06.666430 [ 18285 ] {11c29d8a-8d9c-4df2-8ef7-b1e853bd0092} executeQuery: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50860) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: RESTORE TABLE data AS data_1 FROM S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') SETTINGS use_same_s3_credentials_for_base_backup = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x000000001697e6c3 5. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016979b18 6. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000016978ecc 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995d79 8. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 9. ./build_docker/./src/Backups/BackupsWorker.cpp:932: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr) @ 0x00000000168c3a85 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startRestoring(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168bb180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b9010 12. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 2025.10.24 00:04:06.668816 [ 18285 ] {11c29d8a-8d9c-4df2-8ef7-b1e853bd0092} TCPHandler: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x000000001697e6c3 5. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016979b18 6. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000016978ecc 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995d79 8. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 9. ./build_docker/./src/Backups/BackupsWorker.cpp:932: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr) @ 0x00000000168c3a85 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startRestoring(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168bb180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b9010 12. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 2025.10.24 00:04:07.270345 [ 21659 ] {df833cdc-fe71-494d-95d4-9bdde70fdd98} BackupsWorker: Failed to restore from backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_2', 'test', '[HIDDEN]'): Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_2', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x000000001697e6c3 5. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016979b18 6. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000016978ecc 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995d79 8. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 9. ./build_docker/./src/Backups/BackupsWorker.cpp:932: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr) @ 0x00000000168c3a85 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startRestoring(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168bb180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b9010 12. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:04:07.271522 [ 21659 ] {df833cdc-fe71-494d-95d4-9bdde70fdd98} executeQuery: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_2', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50880) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: RESTORE TABLE data AS data_2 FROM S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_2', 'test', '[HIDDEN]') SETTINGS use_same_s3_credentials_for_base_backup = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x000000001697e6c3 5. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016979b18 6. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000016978ecc 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995d79 8. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 9. ./build_docker/./src/Backups/BackupsWorker.cpp:932: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr) @ 0x00000000168c3a85 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startRestoring(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168bb180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b9010 12. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 2025.10.24 00:04:07.273035 [ 21659 ] {df833cdc-fe71-494d-95d4-9bdde70fdd98} TCPHandler: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_2', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x000000001697e6c3 5. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016979b18 6. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000016978ecc 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995d79 8. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 9. ./build_docker/./src/Backups/BackupsWorker.cpp:932: DB::BackupsWorker::doRestore(std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::RestoreSettings, std::shared_ptr, std::shared_ptr) @ 0x00000000168c3a85 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startRestoring(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168bb180 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b9010 12. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 2025.10.24 00:04:08.004773 [ 18285 ] {3dad3747-ebdb-440b-99f8-bf81a54b3f15} BackupsWorker: Failed to make backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_5_bad', 'test', '[HIDDEN]'): Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x000000001697e6c3 5. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016979b18 6. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000016978ecc 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995d79 8. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 9. ./build_docker/./src/Backups/BackupImpl.cpp:271: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001697f2e2 10. ./build_docker/./src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x0000000016979b4f 11. ./build_docker/./src/Backups/BackupImpl.cpp:145: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x000000001697a667 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995a66 13. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 14. ./build_docker/./src/Backups/BackupsWorker.cpp:609: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168be002 15. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b9a3e 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b905a 17. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:04:08.006131 [ 18285 ] {3dad3747-ebdb-440b-99f8-bf81a54b3f15} executeQuery: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50894) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: BACKUP TABLE data TO S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_5_bad', 'test', '[HIDDEN]') SETTINGS base_backup = S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]', 'foo'), use_same_s3_credentials_for_base_backup = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x000000001697e6c3 5. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016979b18 6. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000016978ecc 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995d79 8. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 9. ./build_docker/./src/Backups/BackupImpl.cpp:271: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001697f2e2 10. ./build_docker/./src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x0000000016979b4f 11. ./build_docker/./src/Backups/BackupImpl.cpp:145: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x000000001697a667 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995a66 13. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 14. ./build_docker/./src/Backups/BackupsWorker.cpp:609: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168be002 15. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b9a3e 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b905a 17. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.24 00:04:08.007863 [ 18285 ] {3dad3747-ebdb-440b-99f8-bf81a54b3f15} TCPHandler: Code: 599. DB::Exception: Backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]') not found. (BACKUP_NOT_FOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::readBackupMetadata() @ 0x000000001697e6c3 5. ./build_docker/./src/Backups/BackupImpl.cpp:200: DB::BackupImpl::open() @ 0x0000000016979b18 6. ./build_docker/./src/Backups/BackupImpl.cpp:112: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool) @ 0x0000000016978ecc 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995d79 8. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 9. ./build_docker/./src/Backups/BackupImpl.cpp:271: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001697f2e2 10. ./build_docker/./src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x0000000016979b4f 11. ./build_docker/./src/Backups/BackupImpl.cpp:145: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x000000001697a667 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x0000000016995a66 13. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 14. ./build_docker/./src/Backups/BackupsWorker.cpp:609: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168be002 15. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b9a3e 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b905a 17. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.24 00:04:08.859805 [ 18285 ] {d0a3ebe9-ab51-4bbc-aba1-25ecae1c5003} BackupsWorker: Failed to make backup S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_6_bad', 'test', '[HIDDEN]', 'foo'): Code: 42. DB::Exception: Backup S3 requires 1 or 3 arguments: url, [access_key_id, secret_access_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Backups/registerBackupEngineS3.cpp:77: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000001699637c 5. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 6. ./build_docker/./src/Backups/BackupsWorker.cpp:609: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168be002 7. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b9a3e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b905a 9. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:04:08.861087 [ 18285 ] {d0a3ebe9-ab51-4bbc-aba1-25ecae1c5003} executeQuery: Code: 42. DB::Exception: Backup S3 requires 1 or 3 arguments: url, [access_key_id, secret_access_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50914) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: BACKUP TABLE data TO S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_6_bad', 'test', '[HIDDEN]', 'foo') SETTINGS base_backup = S3('http://localhost:11111/test/backups/test_1/use_same_s3_credentials_for_base_backup_base_inc_1', 'test', '[HIDDEN]'), use_same_s3_credentials_for_base_backup = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Backups/registerBackupEngineS3.cpp:77: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000001699637c 5. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 6. ./build_docker/./src/Backups/BackupsWorker.cpp:609: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168be002 7. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b9a3e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b905a 9. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:04:08.862471 [ 18285 ] {d0a3ebe9-ab51-4bbc-aba1-25ecae1c5003} TCPHandler: Code: 42. DB::Exception: Backup S3 requires 1 or 3 arguments: url, [access_key_id, secret_access_key]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Backups/registerBackupEngineS3.cpp:77: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x000000001699637c 5. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 6. ./build_docker/./src/Backups/BackupsWorker.cpp:609: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168be002 7. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b9a3e 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b905a 9. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:04:10.354733 [ 18285 ] {0a084585-7d38-4e70-bf56-9168c1ff4506} BackupsWorker: Failed to make backup Disk('backups', 'test_1/backup_2'): Code: 36. DB::Exception: use_same_s3_credentials_for_base_backup supported only for S3, got Disk('backups', 'test_1/backup_2'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Backups/BackupInfo.cpp:0: DB::BackupInfo::copyS3CredentialsTo(DB::BackupInfo&) const @ 0x00000000168b5703 5. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001697efc4 6. ./build_docker/./src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x0000000016979b4f 7. ./build_docker/./src/Backups/BackupImpl.cpp:145: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x000000001697a667 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x00000000169a4025 9. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 10. ./build_docker/./src/Backups/BackupsWorker.cpp:609: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168be002 11. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b9a3e 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b905a 13. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 23. __tsan_thread_start_func @ 0x000000000758df2f 24. ? @ 0x00007f7c69445ac3 25. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:04:10.356806 [ 18285 ] {0a084585-7d38-4e70-bf56-9168c1ff4506} executeQuery: Code: 36. DB::Exception: use_same_s3_credentials_for_base_backup supported only for S3, got Disk('backups', 'test_1/backup_2'). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:44718) (comment: 02843_backup_use_same_s3_credentials_for_base_backup.sh) (in query: BACKUP TABLE data TO Disk('backups', 'test_1/backup_2') SETTINGS use_same_s3_credentials_for_base_backup=1, base_backup=Disk('backups', 'test_1/backup_1')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Backups/BackupInfo.cpp:0: DB::BackupInfo::copyS3CredentialsTo(DB::BackupInfo&) const @ 0x00000000168b5703 5. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001697efc4 6. ./build_docker/./src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x0000000016979b4f 7. ./build_docker/./src/Backups/BackupImpl.cpp:145: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x000000001697a667 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x00000000169a4025 9. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 10. ./build_docker/./src/Backups/BackupsWorker.cpp:609: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168be002 11. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b9a3e 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b905a 13. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 23. __tsan_thread_start_func @ 0x000000000758df2f 24. ? @ 0x00007f7c69445ac3 25. ? @ 0x00007f7c694d7850 2025.10.24 00:04:10.360530 [ 18285 ] {0a084585-7d38-4e70-bf56-9168c1ff4506} TCPHandler: Code: 36. DB::Exception: use_same_s3_credentials_for_base_backup supported only for S3, got Disk('backups', 'test_1/backup_2'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Backups/BackupInfo.cpp:0: DB::BackupInfo::copyS3CredentialsTo(DB::BackupInfo&) const @ 0x00000000168b5703 5. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::getBaseBackupUnlocked() const @ 0x000000001697efc4 6. ./build_docker/./src/Backups/BackupImpl.cpp:201: DB::BackupImpl::open() @ 0x0000000016979b4f 7. ./build_docker/./src/Backups/BackupImpl.cpp:145: DB::BackupImpl::BackupImpl(DB::BackupInfo const&, DB::BackupImpl::ArchiveParams const&, std::optional const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr const&, std::optional, DB::UUIDTag>> const&, bool, bool, bool) @ 0x000000001697a667 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::shared_ptr std::__function::__policy_invoker (DB::BackupFactory::CreateParams const&)>::__call_impl (DB::BackupFactory::CreateParams const&)>>(std::__function::__policy_storage const*, DB::BackupFactory::CreateParams const&) @ 0x00000000169a4025 9. ./build_docker/./src/Backups/BackupFactory.cpp:0: DB::BackupFactory::createBackup(DB::BackupFactory::CreateParams const&) const @ 0x000000001691bb4d 10. ./build_docker/./src/Backups/BackupsWorker.cpp:609: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x00000000168be002 11. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000168b9a3e 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000168b905a 13. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x00000000182c3aa5 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 23. __tsan_thread_start_func @ 0x000000000758df2f 24. ? @ 0x00007f7c69445ac3 25. ? @ 0x00007f7c694d7850 2025.10.24 00:04:16.048163 [ 10932 ] {9a911caa-5b8b-4a04-8a6b-ae29c9de7117} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:48610) (comment: 00174_distinct_in_order.sql) (in query: DROP DATABASE IF EXISTS test_dc0v6nhp ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:04:16.050072 [ 10932 ] {9a911caa-5b8b-4a04-8a6b-ae29c9de7117} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:04:16.122012 [ 21659 ] {79f3be08-e560-4530-ac59-090d81214f4f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:38774) (comment: 00174_distinct_in_order.sql) (in query: DROP DATABASE IF EXISTS test_dc0v6nhp ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:04:16.123789 [ 21659 ] {79f3be08-e560-4530-ac59-090d81214f4f} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:04:16.144047 [ 21666 ] {01782cc0-17d8-4daf-9ad7-096fe9465fda} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:38788) (comment: 00174_distinct_in_order.sql) (in query: DROP DATABASE IF EXISTS test_dc0v6nhp ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:04:16.145563 [ 21666 ] {01782cc0-17d8-4daf-9ad7-096fe9465fda} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:04:16.157656 [ 21659 ] {9aa74f20-5325-4739-a671-dbd634bff5d9} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:38790) (comment: 00174_distinct_in_order.sql) (in query: DROP DATABASE IF EXISTS test_dc0v6nhp ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:04:16.159321 [ 21659 ] {9aa74f20-5325-4739-a671-dbd634bff5d9} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:04:18.529059 [ 21659 ] {72b18420-6194-4772-8c3a-57bbe0081fc0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=746). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:44824) (comment: 02845_arrayShiftRotate.sql) (in query: select arrayRotateRight([1,2,3,4,5], 2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:04:18.529877 [ 21659 ] {72b18420-6194-4772-8c3a-57bbe0081fc0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=746). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:04:19.848525 [ 21659 ] {2ce7c113-a54f-449e-b27f-1f83d8a67310} executeQuery: Code: 6. DB::Exception: Illegal character '\x0d' in partition id starting with 'test_'. (CANNOT_PARSE_TEXT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59228) (comment: 01944_insert_partition_by.sql) (in query: INSERT INTO FUNCTION s3('http://localhost:9001/foo/test_{_partition_id}.csv', 'admin', '[HIDDEN]', 'CSV', 'id Int32, val String') PARTITION BY val FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x0000000019165fa6 4. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x0000000019165984 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:153: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x00000000163891bf 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:125: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000016388c76 7. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x0000000019163a99 8. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x0000000019165058 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7de8ed 10. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a6a6806 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6a6578 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a6a5e75 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a30e90c 17. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1f891e 18. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1ec09e 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.24 00:04:19.916826 [ 21659 ] {2ce7c113-a54f-449e-b27f-1f83d8a67310} TCPHandler: Code: 6. DB::Exception: Illegal character '\x0d' in partition id starting with 'test_'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x0000000019165fa6 4. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x0000000019165984 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:153: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x00000000163891bf 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:125: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000016388c76 7. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x0000000019163a99 8. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x0000000019165058 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7de8ed 10. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a6a6806 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6a6578 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a6a5e75 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a30e90c 17. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1f891e 18. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1ec09e 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.24 00:04:20.081756 [ 21659 ] {4dba1766-c528-4e19-ac96-f82d0410a211} executeQuery: Code: 6. DB::Exception: Illegal character '\x00' in partition id starting with 'test_abc'. (CANNOT_PARSE_TEXT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59228) (comment: 01944_insert_partition_by.sql) (in query: INSERT INTO FUNCTION s3('http://localhost:9001/foo/test_{_partition_id}.csv', 'admin', '[HIDDEN]', 'CSV', 'id Int32, val String') PARTITION BY val FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x0000000019165fa6 4. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x0000000019165984 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:153: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x00000000163891bf 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:125: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000016388c76 7. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x0000000019163a99 8. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x0000000019165058 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7de8ed 10. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a6a6806 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6a6578 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a6a5e75 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a30e90c 17. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1f891e 18. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1ec09e 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.24 00:04:20.145202 [ 21659 ] {4dba1766-c528-4e19-ac96-f82d0410a211} TCPHandler: Code: 6. DB::Exception: Illegal character '\x00' in partition id starting with 'test_abc'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x0000000019165fa6 4. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x0000000019165984 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:153: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x00000000163891bf 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:125: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000016388c76 7. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x0000000019163a99 8. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x0000000019165058 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7de8ed 10. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a6a6806 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6a6578 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a6a5e75 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a30e90c 17. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1f891e 18. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1ec09e 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.24 00:04:20.361990 [ 21659 ] {29f75fdc-4dda-4c2e-b2d0-c933469283d0} executeQuery: Code: 6. DB::Exception: Incorrect non-UTF8 sequence in key. (CANNOT_PARSE_TEXT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59228) (comment: 01944_insert_partition_by.sql) (in query: INSERT INTO FUNCTION s3('http://localhost:9001/foo/test_{_partition_id}.csv', 'admin', '[HIDDEN]', 'CSV', 'id Int32, val String') PARTITION BY val FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:150: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x00000000163892d2 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:125: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000016388c76 6. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x0000000019163a99 7. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x0000000019165058 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7de8ed 9. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a6a6806 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6a6578 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a6a5e75 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a30e90c 16. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1f891e 17. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1ec09e 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.24 00:04:20.371403 [ 21659 ] {29f75fdc-4dda-4c2e-b2d0-c933469283d0} TCPHandler: Code: 6. DB::Exception: Incorrect non-UTF8 sequence in key. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:150: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x00000000163892d2 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:125: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000016388c76 6. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x0000000019163a99 7. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x0000000019165058 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7de8ed 9. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a6a6806 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6a6578 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a6a5e75 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a30e90c 16. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1f891e 17. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1ec09e 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.24 00:04:20.595817 [ 21659 ] {abdd70e7-dcbc-4772-972b-fe08321cfd96} executeQuery: Code: 6. DB::Exception: Illegal character '\x7d' in partition id starting with 'test_abc'. (CANNOT_PARSE_TEXT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59228) (comment: 01944_insert_partition_by.sql) (in query: INSERT INTO FUNCTION s3('http://localhost:9001/foo/test_{_partition_id}.csv', 'admin', '[HIDDEN]', 'CSV', 'id Int32, val String') PARTITION BY val FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x0000000019165fa6 4. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x0000000019165984 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:153: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x00000000163891bf 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:125: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000016388c76 7. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x0000000019163a99 8. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x0000000019165058 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7de8ed 10. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a6a6806 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6a6578 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a6a5e75 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a30e90c 17. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1f891e 18. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1ec09e 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.24 00:04:20.604332 [ 21659 ] {abdd70e7-dcbc-4772-972b-fe08321cfd96} TCPHandler: Code: 6. DB::Exception: Illegal character '\x7d' in partition id starting with 'test_abc'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x0000000019165fa6 4. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x0000000019165984 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:153: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x00000000163891bf 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:125: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000016388c76 7. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x0000000019163a99 8. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x0000000019165058 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7de8ed 10. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a6a6806 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6a6578 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a6a5e75 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a30e90c 17. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1f891e 18. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1ec09e 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.24 00:04:20.795326 [ 21659 ] {ee95b467-a070-4416-bbbb-fe9f70f43c58} executeQuery: Code: 6. DB::Exception: Illegal character '\x2a' in partition id starting with 'test_abc'. (CANNOT_PARSE_TEXT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59228) (comment: 01944_insert_partition_by.sql) (in query: INSERT INTO FUNCTION s3('http://localhost:9001/foo/test_{_partition_id}.csv', 'admin', '[HIDDEN]', 'CSV', 'id Int32, val String') PARTITION BY val FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x0000000019165fa6 4. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x0000000019165984 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:153: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x00000000163891bf 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:125: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000016388c76 7. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x0000000019163a99 8. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x0000000019165058 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7de8ed 10. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a6a6806 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6a6578 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a6a5e75 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a30e90c 17. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1f891e 18. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1ec09e 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.24 00:04:20.805649 [ 21659 ] {ee95b467-a070-4416-bbbb-fe9f70f43c58} TCPHandler: Code: 6. DB::Exception: Illegal character '\x2a' in partition id starting with 'test_abc'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x0000000019165fa6 4. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x0000000019165984 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:153: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x00000000163891bf 6. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:125: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000016388c76 7. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x0000000019163a99 8. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x0000000019165058 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7de8ed 10. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a6a6806 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6a6578 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a6a5e75 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a30e90c 17. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1f891e 18. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1ec09e 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.24 00:04:21.754199 [ 21659 ] {997a052d-7da2-4137-a8a1-417bcb7c3bd3} executeQuery: Code: 36. DB::Exception: Incorrect key length (not empty, max 1023 characters), got: 0. (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59228) (comment: 01944_insert_partition_by.sql) (in query: INSERT INTO FUNCTION s3('http://localhost:9001/foo/{_partition_id}', 'admin', '[HIDDEN]', 'CSV', 'id Int32, val String') PARTITION BY val FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x0000000009320840 4. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:147: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x0000000016389261 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:125: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000016388c76 6. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x0000000019163a99 7. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x0000000019165058 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7de8ed 9. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a6a6806 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6a6578 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a6a5e75 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a30e90c 16. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1f891e 17. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1ec09e 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.24 00:04:21.775658 [ 21659 ] {997a052d-7da2-4137-a8a1-417bcb7c3bd3} TCPHandler: Code: 36. DB::Exception: Incorrect key length (not empty, max 1023 characters), got: 0. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&&) @ 0x0000000009320840 4. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:147: DB::PartitionedStorageObjectStorageSink::validateKey(String const&) @ 0x0000000016389261 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:125: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000016388c76 6. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x0000000019163a99 7. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x0000000019165058 8. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7de8ed 9. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a6a6806 10. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6a6578 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a6a5e75 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 15. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a30e90c 16. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1f891e 17. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1ec09e 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.24 00:04:22.299897 [ 21659 ] {0be60e99-0a43-477e-bfcc-91e5c0a884f2} executeQuery: Code: 36. DB::Exception: Bucket name length is out of bounds in virtual hosted style S3 URI: ''. (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59228) (comment: 01944_insert_partition_by.sql) (in query: INSERT INTO FUNCTION s3('http://localhost:9001/{_partition_id}/key.csv', 'admin', '[HIDDEN]', 'CSV', 'id Int32, val String') PARTITION BY val FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/IO/S3/URI.cpp:0: DB::S3::URI::validateBucket(String const&, Poco::URI const&) @ 0x00000000163d51b8 5. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:0: DB::StorageS3Configuration::validateNamespace(String const&) const @ 0x00000000163c5dd3 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::PartitionedStorageObjectStorageSink::validateNamespace(String const&) @ 0x0000000016389044 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000016388c19 8. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x0000000019163a99 9. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x0000000019165058 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7de8ed 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a6a6806 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6a6578 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a6a5e75 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 17. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a30e90c 18. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1f891e 19. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1ec09e 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 2025.10.24 00:04:22.311541 [ 21659 ] {0be60e99-0a43-477e-bfcc-91e5c0a884f2} TCPHandler: Code: 36. DB::Exception: Bucket name length is out of bounds in virtual hosted style S3 URI: ''. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/IO/S3/URI.cpp:0: DB::S3::URI::validateBucket(String const&, Poco::URI const&) @ 0x00000000163d51b8 5. ./build_docker/./src/Storages/ObjectStorage/S3/Configuration.cpp:0: DB::StorageS3Configuration::validateNamespace(String const&) const @ 0x00000000163c5dd3 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::PartitionedStorageObjectStorageSink::validateNamespace(String const&) @ 0x0000000016389044 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000016388c19 8. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x0000000019163a99 9. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x0000000019165058 10. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7de8ed 11. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a6a6806 12. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6a6578 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a6a5e75 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 17. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a30e90c 18. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1f891e 19. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1ec09e 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 2025.10.24 00:04:22.805292 [ 21659 ] {21d10343-7bbf-4444-8d0e-fbc8b40baa38} executeQuery: Code: 6. DB::Exception: Illegal character '\x2f' in partition id starting with 'aa'. (CANNOT_PARSE_TEXT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59228) (comment: 01944_insert_partition_by.sql) (in query: INSERT INTO FUNCTION s3('http://localhost:9001/{_partition_id}/key.csv', 'admin', '[HIDDEN]', 'CSV', 'id Int32, val String') PARTITION BY val FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x0000000019165fa6 4. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x0000000019165984 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:163: DB::PartitionedStorageObjectStorageSink::validateNamespace(String const&) @ 0x0000000016389089 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000016388c19 7. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x0000000019163a99 8. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x0000000019165058 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7de8ed 10. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a6a6806 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6a6578 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a6a5e75 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a30e90c 17. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1f891e 18. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1ec09e 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.24 00:04:22.816346 [ 21659 ] {21d10343-7bbf-4444-8d0e-fbc8b40baa38} TCPHandler: Code: 6. DB::Exception: Illegal character '\x2f' in partition id starting with 'aa'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, String&&) @ 0x0000000019165fa6 4. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::validatePartitionKey(String const&, bool) @ 0x0000000019165984 5. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:163: DB::PartitionedStorageObjectStorageSink::validateNamespace(String const&) @ 0x0000000016389089 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::PartitionedStorageObjectStorageSink::createSinkForPartition(String const&) @ 0x0000000016388c19 7. ./build_docker/./src/Storages/PartitionedSink.cpp:47: DB::PartitionedSink::getSinkForPartitionKey(StringRef) @ 0x0000000019163a99 8. ./build_docker/./src/Storages/PartitionedSink.cpp:0: DB::PartitionedSink::consume(DB::Chunk&) @ 0x0000000019165058 9. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000001a7de8ed 10. ./contrib/llvm-project/libcxx/include/vector:438: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a6a6806 11. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000001a6a6578 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a6a5e75 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 16. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000001a30e90c 17. ./build_docker/./src/Server/TCPHandler.cpp:993: DB::TCPHandler::processInsertQuery() @ 0x000000001a1f891e 18. ./build_docker/./src/Server/TCPHandler.cpp:586: DB::TCPHandler::runImpl() @ 0x000000001a1ec09e 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.24 00:04:26.516967 [ 18285 ] {1d6e8482-6624-4e9b-bf57-a3dc2d9ebd57} executeQuery: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different types: 1 UInt8 Const(size = 0, UInt8(size = 1)) 1 Nullable(Nothing) Const(size = 0, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))). (AMBIGUOUS_COLUMN_NAME) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59286) (comment: 01950_aliases_bad_cast.sql) (in query: SELECT 1, * FROM (SELECT NULL AS `1`);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x00000000169c972c 4. ./build_docker/./src/Core/Block.cpp:36: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x00000000169baf20 5. ./build_docker/./src/Core/Block.cpp:0: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x00000000169bba1c 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000173fb38c 7. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001a6a6dea 8. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:32: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000001a8d7de7 9. ./contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x000000001623d2a2 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000017dd5865 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dd0fc9 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 23. __tsan_thread_start_func @ 0x000000000758df2f 24. ? @ 0x00007f7c69445ac3 25. ? @ 0x00007f7c694d7850 2025.10.24 00:04:26.519872 [ 18285 ] {1d6e8482-6624-4e9b-bf57-a3dc2d9ebd57} TCPHandler: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different types: 1 UInt8 Const(size = 0, UInt8(size = 1)) 1 Nullable(Nothing) Const(size = 0, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))). (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x00000000169c972c 4. ./build_docker/./src/Core/Block.cpp:36: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x00000000169baf20 5. ./build_docker/./src/Core/Block.cpp:0: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x00000000169bba1c 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000173fb38c 7. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001a6a6dea 8. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:32: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000001a8d7de7 9. ./contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x000000001623d2a2 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000017dd5865 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dd0fc9 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 23. __tsan_thread_start_func @ 0x000000000758df2f 24. ? @ 0x00007f7c69445ac3 25. ? @ 0x00007f7c694d7850 2025.10.24 00:04:26.612461 [ 18285 ] {e5937ebd-b320-41c8-b15d-4a55a8e78e75} executeQuery: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different types: 'xyz' String Const(size = 0, String(size = 1)) 'xyz' Nullable(Nothing) Const(size = 0, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))). (AMBIGUOUS_COLUMN_NAME) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59286) (comment: 01950_aliases_bad_cast.sql) (in query: SELECT '7', 'xyz', * FROM (SELECT NULL AS `'xyz'`);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x00000000169c972c 4. ./build_docker/./src/Core/Block.cpp:36: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x00000000169baf20 5. ./build_docker/./src/Core/Block.cpp:0: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x00000000169bba1c 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000173fb38c 7. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001a6a6dea 8. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:32: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000001a8d7de7 9. ./contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x000000001623d2a2 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000017dd5865 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dd0fc9 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 23. __tsan_thread_start_func @ 0x000000000758df2f 24. ? @ 0x00007f7c69445ac3 25. ? @ 0x00007f7c694d7850 2025.10.24 00:04:26.613627 [ 18285 ] {e5937ebd-b320-41c8-b15d-4a55a8e78e75} TCPHandler: Code: 352. DB::Exception: Block structure mismatch in (columns with identical name must have identical structure) stream: different types: 'xyz' String Const(size = 0, String(size = 1)) 'xyz' Nullable(Nothing) Const(size = 0, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))). (AMBIGUOUS_COLUMN_NAME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception>&, String, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&) @ 0x00000000169c972c 4. ./build_docker/./src/Core/Block.cpp:36: void DB::checkColumnStructure(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::basic_string_view>, bool, int) @ 0x00000000169baf20 5. ./build_docker/./src/Core/Block.cpp:0: DB::Block::insert(DB::ColumnWithTypeAndName) @ 0x00000000169bba1c 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000173fb38c 7. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000001a6a6dea 8. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:32: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000001a8d7de7 9. ./contrib/llvm-project/libcxx/include/vector:438: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&) @ 0x000000001623d2a2 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000017dd5865 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000017dd0fc9 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000017dc6523 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000017dc373b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x000000001822021e 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 23. __tsan_thread_start_func @ 0x000000000758df2f 24. ? @ 0x00007f7c69445ac3 25. ? @ 0x00007f7c694d7850 2025.10.24 00:04:35.056088 [ 3228 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:04:36.095956 [ 2893 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:04:41.964467 [ 22371 ] {a0a39198-7b19-49ac-9d0b-4e5750281117} executeQuery: Code: 410. DB::Exception: BridgeHelper: clickhouse-odbc-bridge is not responding. (EXTERNAL_SERVER_IS_NOT_RESPONDING) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:33832) (comment: 01086_odbc_roundtrip.sh) (in query: select count() > 1 as ok from (select * from odbc('DSN={ClickHouse DSN (ANSI)}','system','tables'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/BridgeHelper/IBridgeHelper.cpp:0: DB::IBridgeHelper::startBridgeSync() @ 0x000000001a0d9a59 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::ITableFunctionXDBC::startBridgeIfNot(std::shared_ptr) const @ 0x0000000015ea5d74 6. ./build_docker/./src/TableFunctions/ITableFunctionXDBC.cpp:0: DB::(anonymous namespace)::ITableFunctionXDBC::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015ea567d 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 8. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1bbd 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d690b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:04:41.966706 [ 22371 ] {a0a39198-7b19-49ac-9d0b-4e5750281117} TCPHandler: Code: 410. DB::Exception: BridgeHelper: clickhouse-odbc-bridge is not responding. (EXTERNAL_SERVER_IS_NOT_RESPONDING), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/BridgeHelper/IBridgeHelper.cpp:0: DB::IBridgeHelper::startBridgeSync() @ 0x000000001a0d9a59 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::ITableFunctionXDBC::startBridgeIfNot(std::shared_ptr) const @ 0x0000000015ea5d74 6. ./build_docker/./src/TableFunctions/ITableFunctionXDBC.cpp:0: DB::(anonymous namespace)::ITableFunctionXDBC::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015ea567d 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 8. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1bbd 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d690b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:04:42.419366 [ 3311 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3391eeb9-30c2-4727-900d-ef688a8fcf48::202510_1_137_28}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:04:42.881844 [ 21659 ] {0e050486-77b8-415e-b528-332aec57b33a} executeQuery: Code: 16. DB::Exception: No such column ord in table test_1.t (5acdad6d-ba00-4037-9a41-5ac417ccce5f). (NO_SUCH_COLUMN_IN_TABLE) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:37388) (comment: 03215_multilinestring_geometry.sql) (in query: INSERT INTO t (ord, shape, wkt_string) VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x0000000017d47920 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x0000000017d46b2d 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:761: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f35d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.24 00:04:42.883378 [ 21659 ] {0e050486-77b8-415e-b528-332aec57b33a} TCPHandler: Code: 16. DB::Exception: No such column ord in table test_1.t (5acdad6d-ba00-4037-9a41-5ac417ccce5f). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x0000000017d47920 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x0000000017d46b2d 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:761: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f35d 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.24 00:04:44.446659 [ 21659 ] {adabe015-ec73-4f5a-84bf-fe37318a298c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=747). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:37416) (comment: 01999_grant_with_replace.sql) (in query: SHOW GRANTS FOR test_user_01999;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:04:44.448210 [ 21659 ] {adabe015-ec73-4f5a-84bf-fe37318a298c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=747). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:04:52.384611 [ 22188 ] {b20fe68f-4cb2-4f38-99dd-1c34fb44e9bf} executeQuery: Code: 57. DB::Exception: Table test_1.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36776) (comment: 01160_table_dependencies.sh) (in query: CREATE TABLE t (`n` int, `m` int DEFAULT joinGet(test_1.join, 'm', CAST('42', 'int')), `s` String DEFAULT dictGet(test_1.dict1, 's', CAST('42', 'UInt64')), `y` DEFAULT dictGet(test_1.dict2, 'm', CAST('42', 'UInt64'))) ENGINE = MergeTree ORDER BY n SETTINGS index_granularity = 57488, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 399999787, compact_parts_max_bytes_to_buffer = 53605973, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 11004867, merge_max_block_size = 20825, old_parts_lifetime = 11., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1412993403, index_granularity_bytes = 14160587, concurrent_part_removal_threshold = 91, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 37483, primary_key_compress_block_size = 69697), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.24 00:04:52.386937 [ 22188 ] {b20fe68f-4cb2-4f38-99dd-1c34fb44e9bf} TCPHandler: Code: 57. DB::Exception: Table test_1.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.24 00:04:54.118184 [ 22188 ] {04097a49-9047-432d-af99-9b40bc4c29bf} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `y` to drop. Maybe you meant: ['x']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36804) (comment: 01160_table_dependencies.sh) (in query: alter table t add column x int default in(1, test_1.s), drop column y), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000190eea56 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c296ab 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.24 00:04:54.120097 [ 22188 ] {04097a49-9047-432d-af99-9b40bc4c29bf} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `y` to drop. Maybe you meant: ['x']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000190eea56 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000017c296ab 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000017c26f63 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.24 00:04:55.346566 [ 22188 ] {a4704085-0be3-4713-b487-019f55c74f83} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'n' in scope SELECT n AS x FROM test_1.t WHERE n IN (SELECT n FROM test_1.join). Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36810) (comment: 01160_table_dependencies.sh) (in query: create materialized view mv to s as select n as x from t where n in (select n from join)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc2d4c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c437f8 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4d006 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 2025.10.24 00:04:55.351301 [ 22188 ] {a4704085-0be3-4713-b487-019f55c74f83} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'n' in scope SELECT n AS x FROM test_1.t WHERE n IN (SELECT n FROM test_1.join). Maybe you meant: ['x']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000017dc2d4c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c437f8 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4d006 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 26. __tsan_thread_start_func @ 0x000000000758df2f 27. ? @ 0x00007f7c69445ac3 28. ? @ 0x00007f7c694d7850 2025.10.24 00:04:56.673838 [ 22188 ] {c28a6184-c650-48ae-aa12-2f16fbeb9cd8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36852) (comment: 01160_table_dependencies.sh) (in query: detach database test_1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017c78f8e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.24 00:04:56.675427 [ 22188 ] {c28a6184-c650-48ae-aa12-2f16fbeb9cd8} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017c78f8e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.24 00:04:57.526677 [ 22188 ] {0cffeb83-30dd-407e-86b2-fb1b8e11d830} executeQuery: Code: 82. DB::Exception: Database test_1 already exists. (DATABASE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36866) (comment: 01160_table_dependencies.sh) (in query: attach database test_1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:147: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3aa71 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2042: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a57c 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.24 00:04:57.528380 [ 22188 ] {0cffeb83-30dd-407e-86b2-fb1b8e11d830} TCPHandler: Code: 82. DB::Exception: Database test_1 already exists. (DATABASE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:147: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3aa71 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2042: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a57c 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.24 00:04:58.298094 [ 10932 ] {41f51af1-e53c-4cad-a704-7c50859e1959} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36882) (comment: 01160_table_dependencies.sh) (in query: detach database test_1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017c78f8e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.24 00:04:58.357819 [ 10932 ] {41f51af1-e53c-4cad-a704-7c50859e1959} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017c78f8e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.24 00:04:58.927465 [ 22188 ] {f719c04e-2c56-4b60-9452-8bcc0206b222} executeQuery: Code: 82. DB::Exception: Database test_1 already exists. (DATABASE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36890) (comment: 01160_table_dependencies.sh) (in query: attach database test_1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:147: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3aa71 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2042: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a57c 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.24 00:04:58.929028 [ 22188 ] {f719c04e-2c56-4b60-9452-8bcc0206b222} TCPHandler: Code: 82. DB::Exception: Database test_1 already exists. (DATABASE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:147: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3aa71 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2042: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a57c 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.24 00:04:59.802737 [ 22188 ] {64784e26-38f7-4e06-9a19-79a9ae4f80e5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:34328) (comment: 01160_table_dependencies.sh) (in query: detach database test_1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017c78f8e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.24 00:04:59.804856 [ 22188 ] {64784e26-38f7-4e06-9a19-79a9ae4f80e5} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017c78f8e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.24 00:05:00.368631 [ 10932 ] {d568b71e-1d15-4b3b-b233-71af55c9f13a} executeQuery: Code: 82. DB::Exception: Database test_1 already exists. (DATABASE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:34360) (comment: 01160_table_dependencies.sh) (in query: attach database test_1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:147: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3aa71 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2042: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a57c 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.24 00:05:00.370139 [ 10932 ] {d568b71e-1d15-4b3b-b233-71af55c9f13a} TCPHandler: Code: 82. DB::Exception: Database test_1 already exists. (DATABASE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:147: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3aa71 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2042: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a57c 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.24 00:05:00.896045 [ 22188 ] {84222833-830b-4c3b-ab2c-42efa601e87f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:34374) (comment: 01160_table_dependencies.sh) (in query: detach database test_1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017c78f8e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.24 00:05:00.897971 [ 22188 ] {84222833-830b-4c3b-ab2c-42efa601e87f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000017c78f8e 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.24 00:05:01.182493 [ 2716 ] {} test_1.ANIMAL (37e9870e-4e6d-428c-8002-223e2327e96a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test/test_1/animal/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000001933e680 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193dcf00 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019498822 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 12. __tsan_thread_start_func @ 0x000000000758df2f 13. ? @ 0x00007f7c69445ac3 14. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:01.525586 [ 10932 ] {aff4a702-1441-4584-ba14-34fe870361c4} executeQuery: Code: 82. DB::Exception: Database test_1 already exists. (DATABASE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:34386) (comment: 01160_table_dependencies.sh) (in query: attach database test_1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:147: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3aa71 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2042: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a57c 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.24 00:05:01.528478 [ 10932 ] {aff4a702-1441-4584-ba14-34fe870361c4} TCPHandler: Code: 82. DB::Exception: Database test_1 already exists. (DATABASE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:147: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3aa71 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2042: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a57c 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007f7c69445ac3 17. ? @ 0x00007f7c694d7850 2025.10.24 00:05:02.169951 [ 3218 ] {} test_1.test_alter_on_mutation (6b9c395c-8ba2-4cf9-895d-021328ff8e3d): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/test_01062/alter_on_mutation/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000001933e680 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193dcf00 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019498822 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 12. __tsan_thread_start_func @ 0x000000000758df2f 13. ? @ 0x00007f7c69445ac3 14. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:02.448448 [ 3198 ] {} test_1.quorum1 (7da06c68-244d-4a22-a2a6-4d336cbad52e): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/test_00732/quorum1/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000001933e680 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193dcf00 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019498822 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 12. __tsan_thread_start_func @ 0x000000000758df2f 13. ? @ 0x00007f7c69445ac3 14. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:02.481722 [ 3197 ] {} test_1.rename1 (1deab9d2-9a08-46e7-929c-0c4f7f50b811): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000762daa0 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000001933e680 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x00000000193dcf00 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019498822 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 12. __tsan_thread_start_func @ 0x000000000758df2f 13. ? @ 0x00007f7c69445ac3 14. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:03.418110 [ 22188 ] {e4bf558e-d151-420c-a130-e06c251bd318} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:34408) (comment: 01160_table_dependencies.sh) (in query: attach database test_1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:685: DB::DatabaseOnDisk::iterateMetadataFiles(std::shared_ptr, std::function const&) const @ 0x00000000170a593d 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000170c8fcd 9. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c68f71 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3a20e 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2042: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a57c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.24 00:05:03.419555 [ 22188 ] {e4bf558e-d151-420c-a130-e06c251bd318} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1f0b7 7. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:685: DB::DatabaseOnDisk::iterateMetadataFiles(std::shared_ptr, std::function const&) const @ 0x00000000170a593d 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000170c8fcd 9. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000017c68f71 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3a20e 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2042: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a57c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.24 00:05:04.369088 [ 22188 ] {40330ea7-4008-4b7f-85a0-f5b06c87a5f2} executeQuery: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:34422) (comment: 01160_table_dependencies.sh) (in query: detach database test_1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001769c8cf 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c78608 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:05:04.371035 [ 22188 ] {40330ea7-4008-4b7f-85a0-f5b06c87a5f2} TCPHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001769c8cf 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c78608 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:05:05.051305 [ 3100 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:05.103723 [ 22188 ] {e9c144f5-8b02-44e0-beab-f32102792f96} TablesLoader: Tables test_1.dist_01247 depend on default.number, but seems like that does not exist. Will ignore it and try to load existing tables 2025.10.24 00:05:05.499827 [ 8858 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6): Cannot attach table `test_1`.`mutation_table` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/mutation_table.sql from query ATTACH TABLE test_1.mutation_table UUID 'b9687add-90e5-4a33-8f93-b03215c81b58' (`id` Int32, `price` Nullable(Int32)) ENGINE = MergeTree PARTITION BY id ORDER BY id SETTINGS index_granularity = 20225, min_bytes_for_wide_part = 987037268, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 53, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 483153863, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 1490477, merge_max_block_size = 1902, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 4917032244, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 2515658, concurrent_part_removal_threshold = 99, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 60600, primary_key_compress_block_size = 62330. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:05.499862 [ 11323 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6): Cannot attach table `test_1`.`test_max_size_drop` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/test_max_size_drop.sql from query ATTACH TABLE test_1.test_max_size_drop UUID '78a81279-3e18-434e-9475-ae4cf00e5135' (`number` UInt64) ENGINE = MergeTree ORDER BY number SETTINGS index_granularity = 45576, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 3, min_bytes_for_full_part_storage = 286198050, compact_parts_max_bytes_to_buffer = 356249003, compact_parts_max_granules_to_buffer = 41, compact_parts_merge_max_bytes_to_prefetch_part = 18775713, merge_max_block_size = 11732, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 11093386, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 46509, primary_key_compress_block_size = 64121. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:06.085922 [ 22188 ] {e9c144f5-8b02-44e0-beab-f32102792f96} executeQuery: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_1.mutation_table' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6): Cannot attach table `test_1`.`mutation_table` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/mutation_table.sql from query ATTACH TABLE test_1.mutation_table UUID 'b9687add-90e5-4a33-8f93-b03215c81b58' (`id` Int32, `price` Nullable(Int32)) ENGINE = MergeTree PARTITION BY id ORDER BY id SETTINGS index_granularity = 20225, min_bytes_for_wide_part = 987037268, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 53, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 483153863, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 1490477, merge_max_block_size = 1902, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 4917032244, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 2515658, concurrent_part_removal_threshold = 99, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 60600, primary_key_compress_block_size = 62330. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10544.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:34440) (comment: 01160_table_dependencies.sh) (in query: attach database test_1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Common/AsyncLoader.cpp:0: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x000000000fcc4e50 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000000fc7efae 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3a3b5 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2042: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a57c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:05:06.088184 [ 22188 ] {e9c144f5-8b02-44e0-beab-f32102792f96} TCPHandler: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_1.mutation_table' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6): Cannot attach table `test_1`.`mutation_table` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/mutation_table.sql from query ATTACH TABLE test_1.mutation_table UUID 'b9687add-90e5-4a33-8f93-b03215c81b58' (`id` Int32, `price` Nullable(Int32)) ENGINE = MergeTree PARTITION BY id ORDER BY id SETTINGS index_granularity = 20225, min_bytes_for_wide_part = 987037268, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 53, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 483153863, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 1490477, merge_max_block_size = 1902, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 4917032244, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 2515658, concurrent_part_removal_threshold = 99, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 60600, primary_key_compress_block_size = 62330. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10544.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Common/AsyncLoader.cpp:0: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x000000000fcc4e50 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000000fc7efae 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3a3b5 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2042: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a57c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:05:06.698028 [ 22188 ] {fcc72012-1ab4-41c8-88a9-9084c44ecda8} executeQuery: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:34470) (comment: 01160_table_dependencies.sh) (in query: detach database test_1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001769c8cf 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c78608 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:05:06.700051 [ 22188 ] {fcc72012-1ab4-41c8-88a9-9084c44ecda8} TCPHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001769c8cf 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c78608 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:05:07.491581 [ 22188 ] {81a9fd35-9a33-49ad-a4fa-815122545590} TablesLoader: Tables test_1.dist_01247 depend on default.number, but seems like that does not exist. Will ignore it and try to load existing tables 2025.10.24 00:05:07.859864 [ 5109 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1): Cannot attach table `test_1`.`.inner_id.78acb166-a53d-4c67-9170-61397da1160e` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/%2Einner_id%2E78acb166%2Da53d%2D4c67%2D9170%2D61397da1160e.sql from query ATTACH TABLE test_1.`.inner_id.78acb166-a53d-4c67-9170-61397da1160e` UUID '86354fb3-941b-46ec-a008-ce07682e9b66' (`ddate` Date, `bar_id` Int64, `bar_n` String, `foo_id` Int64, `foo_n` Nullable(String)) ENGINE = ReplacingMergeTree(ddate, bar_id, 8192). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:07.883708 [ 23318 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2): Cannot attach table `test_1`.`t_async_insert_native_3` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/t_async_insert_native_3.sql from query ATTACH TABLE test_1.t_async_insert_native_3 UUID 'b7c82092-fc55-45e6-a402-b70decc9758d' (`id` UInt64, `s` String) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 14768, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.11309942603111267, replace_long_file_name_to_hash = true, max_file_name_length = 15, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 483227420, compact_parts_max_granules_to_buffer = 223, compact_parts_merge_max_bytes_to_prefetch_part = 23639310, merge_max_block_size = 3893, old_parts_lifetime = 108., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 519965, concurrent_part_removal_threshold = 79, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 24684, primary_key_compress_block_size = 12848. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199c2371 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c5d03 10. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 14. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 15. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:07.926337 [ 5110 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=13): Cannot attach table `test_1`.`async_inserts` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/async_inserts.sql from query ATTACH TABLE test_1.async_inserts UUID '280da388-a196-423d-b5a5-866cba0085a6' (`id` UInt32, `s` String) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 8192. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199c2371 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c5d03 10. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 14. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 15. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:07.926632 [ 11319 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7): Cannot attach table `test_1`.`mytable_local` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/mytable_local.sql from query ATTACH TABLE test_1.mytable_local UUID '2c2e948b-9ed3-41c9-bb4c-203f6d19637e' (`created` DateTime, `eventday` Date, `user_id` UInt32) ENGINE = MergeTree PARTITION BY toYYYYMM(eventday) ORDER BY (eventday, user_id) SETTINGS index_granularity = 6479, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.5217880606651306, replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 393007512, compact_parts_max_granules_to_buffer = 170, compact_parts_merge_max_bytes_to_prefetch_part = 1422810, merge_max_block_size = 9977, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 4608320563, index_granularity_bytes = 25010464, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 94668, primary_key_compress_block_size = 25129. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199c2371 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c5d03 10. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 14. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 15. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:08.142527 [ 22188 ] {81a9fd35-9a33-49ad-a4fa-815122545590} executeQuery: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_1.mytable_local' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7): Cannot attach table `test_1`.`mytable_local` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/mytable_local.sql from query ATTACH TABLE test_1.mytable_local UUID '2c2e948b-9ed3-41c9-bb4c-203f6d19637e' (`created` DateTime, `eventday` Date, `user_id` UInt32) ENGINE = MergeTree PARTITION BY toYYYYMM(eventday) ORDER BY (eventday, user_id) SETTINGS index_granularity = 6479, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.5217880606651306, replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 393007512, compact_parts_max_granules_to_buffer = 170, compact_parts_merge_max_bytes_to_prefetch_part = 1422810, merge_max_block_size = 9977, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 4608320563, index_granularity_bytes = 25010464, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 94668, primary_key_compress_block_size = 25129. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199c2371 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c5d03 10. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 14. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 15. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10544.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:34476) (comment: 01160_table_dependencies.sh) (in query: attach database test_1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Common/AsyncLoader.cpp:0: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x000000000fcc4e50 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000000fc7efae 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3a3b5 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2042: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a57c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:05:08.148109 [ 22188 ] {81a9fd35-9a33-49ad-a4fa-815122545590} TCPHandler: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_1.mytable_local' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7): Cannot attach table `test_1`.`mytable_local` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/mytable_local.sql from query ATTACH TABLE test_1.mytable_local UUID '2c2e948b-9ed3-41c9-bb4c-203f6d19637e' (`created` DateTime, `eventday` Date, `user_id` UInt32) ENGINE = MergeTree PARTITION BY toYYYYMM(eventday) ORDER BY (eventday, user_id) SETTINGS index_granularity = 6479, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.5217880606651306, replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 393007512, compact_parts_max_granules_to_buffer = 170, compact_parts_merge_max_bytes_to_prefetch_part = 1422810, merge_max_block_size = 9977, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 4608320563, index_granularity_bytes = 25010464, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 94668, primary_key_compress_block_size = 25129. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199c2371 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c5d03 10. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 14. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 15. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10544.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Common/AsyncLoader.cpp:0: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x000000000fcc4e50 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000000fc7efae 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3a3b5 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2042: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a57c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:05:08.729013 [ 10932 ] {01298e0c-7e65-468a-a331-1db6e826afc0} executeQuery: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:34514) (comment: 01160_table_dependencies.sh) (in query: detach database test_1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001769c8cf 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c78608 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:05:08.731594 [ 10932 ] {01298e0c-7e65-468a-a331-1db6e826afc0} TCPHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001769c8cf 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c78608 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:05:09.690391 [ 22188 ] {642e52d5-a3ac-4e1b-9459-3978b4490a9c} TablesLoader: Tables test_1.dist_01247 depend on default.number, but seems like that does not exist. Will ignore it and try to load existing tables 2025.10.24 00:05:09.882120 [ 8857 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5): Cannot attach table `test_1`.`lc_dict_reading` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/lc_dict_reading.sql from query ATTACH TABLE test_1.lc_dict_reading UUID '94402e1f-eb6f-42ff-a142-b88bd5eb02e2' (`val` UInt64, `str` LowCardinality(String), `pat` String) ENGINE = MergeTree ORDER BY val SETTINGS index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 301460341, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 373283845, compact_parts_max_granules_to_buffer = 41, compact_parts_merge_max_bytes_to_prefetch_part = 13359374, merge_max_block_size = 20850, old_parts_lifetime = 88., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1263063662, concurrent_part_removal_threshold = 15, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 89321, primary_key_compress_block_size = 32369. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:09.967098 [ 23320 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6): Cannot attach table `test_1`.`t_mt_async_insert` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/t_mt_async_insert.sql from query ATTACH TABLE test_1.t_mt_async_insert UUID 'e80f0440-33bd-4965-9228-62caeeb5e85e' (`id` UInt64, `s` String) ENGINE = MergeTree ORDER BY id SETTINGS async_insert = 1, index_granularity = 14606, min_bytes_for_wide_part = 121989978, ratio_of_defaults_for_sparse_serialization = 0.3068198263645172, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 148967522, compact_parts_max_bytes_to_buffer = 106914334, compact_parts_max_granules_to_buffer = 91, compact_parts_merge_max_bytes_to_prefetch_part = 6318330, merge_max_block_size = 13452, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 1430270, concurrent_part_removal_threshold = 75, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 46350, primary_key_compress_block_size = 56851. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199c2371 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c5d03 10. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 14. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 15. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:10.065459 [ 23320 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8): Cannot attach table `test_1`.`auto_assign_enum` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/auto_assign_enum.sql from query ATTACH TABLE test_1.auto_assign_enum UUID '1a7cf51c-81eb-464c-8f63-c62af740557c' (`x` Enum8('a' = 1, 'b' = 2)) ENGINE = MergeTree ORDER BY x SETTINGS index_granularity = 146, min_bytes_for_wide_part = 744042464, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 421213770, compact_parts_max_bytes_to_buffer = 394111719, compact_parts_max_granules_to_buffer = 101, compact_parts_merge_max_bytes_to_prefetch_part = 18123859, merge_max_block_size = 6827, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 731638401, index_granularity_bytes = 27480851, concurrent_part_removal_threshold = 87, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 41261, primary_key_compress_block_size = 98097. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199c2371 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c5d03 10. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 14. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 15. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:10.080224 [ 11326 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7): Cannot attach table `test_1`.`async_inserts` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/async_inserts.sql from query ATTACH TABLE test_1.async_inserts UUID '280da388-a196-423d-b5a5-866cba0085a6' (`id` UInt32, `s` String) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 8192. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199c2371 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c5d03 10. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 14. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 15. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:10.936582 [ 22188 ] {642e52d5-a3ac-4e1b-9459-3978b4490a9c} virtual void DB::StorageBuffer::flushAndPrepareForShutdown(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageBuffer::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000195f1bd0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::StorageBuffer::flushAndPrepareForShutdown() @ 0x00000000195f19f7 11. ./contrib/llvm-project/libcxx/include/__tree:189: DB::DatabaseWithOwnTablesBase::shutdown() @ 0x0000000017136b19 12. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:184: DB::DatabaseOnDisk::shutdown() @ 0x000000001709b0eb 13. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:606: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769adf1 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:380: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3bab5 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2042: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a57c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:11.001576 [ 22188 ] {642e52d5-a3ac-4e1b-9459-3978b4490a9c} executeQuery: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_1.auto_assign_enum' failed: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8): Cannot attach table `test_1`.`auto_assign_enum` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/auto_assign_enum.sql from query ATTACH TABLE test_1.auto_assign_enum UUID '1a7cf51c-81eb-464c-8f63-c62af740557c' (`x` Enum8('a' = 1, 'b' = 2)) ENGINE = MergeTree ORDER BY x SETTINGS index_granularity = 146, min_bytes_for_wide_part = 744042464, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 421213770, compact_parts_max_bytes_to_buffer = 394111719, compact_parts_max_granules_to_buffer = 101, compact_parts_merge_max_bytes_to_prefetch_part = 18123859, merge_max_block_size = 6827, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 731638401, index_granularity_bytes = 27480851, concurrent_part_removal_threshold = 87, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 41261, primary_key_compress_block_size = 98097. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199c2371 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c5d03 10. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 14. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 15. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10544.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59152) (comment: 01160_table_dependencies.sh) (in query: attach database test_1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Common/AsyncLoader.cpp:0: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x000000000fcc4e50 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000000fc7efae 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3a3b5 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2042: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a57c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:05:11.006312 [ 22188 ] {642e52d5-a3ac-4e1b-9459-3978b4490a9c} TCPHandler: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_1.auto_assign_enum' failed: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8): Cannot attach table `test_1`.`auto_assign_enum` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/auto_assign_enum.sql from query ATTACH TABLE test_1.auto_assign_enum UUID '1a7cf51c-81eb-464c-8f63-c62af740557c' (`x` Enum8('a' = 1, 'b' = 2)) ENGINE = MergeTree ORDER BY x SETTINGS index_granularity = 146, min_bytes_for_wide_part = 744042464, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 421213770, compact_parts_max_bytes_to_buffer = 394111719, compact_parts_max_granules_to_buffer = 101, compact_parts_merge_max_bytes_to_prefetch_part = 18123859, merge_max_block_size = 6827, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 731638401, index_granularity_bytes = 27480851, concurrent_part_removal_threshold = 87, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 41261, primary_key_compress_block_size = 98097. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199c2371 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c5d03 10. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 14. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 15. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10544.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Common/AsyncLoader.cpp:0: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x000000000fcc4e50 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000000fc7efae 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3a3b5 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2042: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a57c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:05:11.127289 [ 2947 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:11.641202 [ 22188 ] {96623365-bd87-427a-9b85-009f7e849f55} executeQuery: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59182) (comment: 01160_table_dependencies.sh) (in query: detach database test_1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001769c8cf 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c78608 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:05:11.642482 [ 22188 ] {96623365-bd87-427a-9b85-009f7e849f55} TCPHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001769c8cf 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c78608 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:05:12.479047 [ 22188 ] {25f369b4-d053-43c0-9852-d08840bcb27e} TablesLoader: Tables test_1.dist_01247 depend on default.number, but seems like that does not exist. Will ignore it and try to load existing tables 2025.10.24 00:05:12.630672 [ 11329 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1): Cannot attach table `test_1`.`Test` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/Test.sql from query ATTACH TABLE test_1.Test UUID 'f4eb7080-f585-4f8b-90ac-57eda7b1f5d0' (`String1` String, `String2` String, `String3` String, `String4` String) ENGINE = MergeTree PRIMARY KEY (String1, String2) ORDER BY (String1, String2) SETTINGS index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 200945594, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 431261019, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 14472391, merge_max_block_size = 13458, old_parts_lifetime = 297., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1534661496, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 60438, primary_key_compress_block_size = 18899. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199c2371 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c5d03 10. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 14. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 15. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:12.650315 [ 8858 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=3, jobs=3): Cannot attach table `test_1`.`test_bm` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/test_bm.sql from query ATTACH TABLE test_1.test_bm UUID '4108c352-6764-4c19-8931-29486ba17e21' (`dim` UInt64, `id` UInt64) ENGINE = MergeTree ORDER BY (dim, id) SETTINGS index_granularity = 8192, min_bytes_for_wide_part = 92543720, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 7, min_bytes_for_full_part_storage = 33377119, compact_parts_max_bytes_to_buffer = 427964698, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8087794, merge_max_block_size = 20924, old_parts_lifetime = 373., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 2868800162, index_granularity_bytes = 23287569, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 74180, primary_key_compress_block_size = 85331. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:12.669200 [ 23316 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=4, jobs=4): Cannot attach table `test_1`.`table_for_dict` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/table_for_dict.sql from query ATTACH TABLE test_1.table_for_dict UUID 'aceada42-d10d-4a86-babc-6bba5c2dc976' (`key_column` UInt64, `value` Float64) ENGINE = MergeTree ORDER BY key_column SETTINGS index_granularity = 52704, min_bytes_for_wide_part = 1062225053, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 49, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 283495453, compact_parts_max_granules_to_buffer = 210, compact_parts_merge_max_bytes_to_prefetch_part = 32205280, merge_max_block_size = 23682, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 3310543823, index_granularity_bytes = 8261818, concurrent_part_removal_threshold = 73, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 75756, primary_key_compress_block_size = 73885. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199c2371 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c5d03 10. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 14. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 15. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:12.686588 [ 11322 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=3, jobs=3): Cannot attach table `test_1`.`mutation_table` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/mutation_table.sql from query ATTACH TABLE test_1.mutation_table UUID 'b9687add-90e5-4a33-8f93-b03215c81b58' (`id` Int32, `price` Nullable(Int32)) ENGINE = MergeTree PARTITION BY id ORDER BY id SETTINGS index_granularity = 20225, min_bytes_for_wide_part = 987037268, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 53, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 483153863, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 1490477, merge_max_block_size = 1902, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 4917032244, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 2515658, concurrent_part_removal_threshold = 99, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 60600, primary_key_compress_block_size = 62330. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:12.738170 [ 5110 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4): Cannot attach table `test_1`.`t_sparse_full` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/t_sparse_full.sql from query ATTACH TABLE test_1.t_sparse_full UUID '99c791d1-eeb3-4b55-b111-8a3940e3e6cf' (`id` UInt64, `u` UInt64, `s` String) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 32, index_granularity_bytes = '10Mi', ratio_of_defaults_for_sparse_serialization = 0.1, min_bytes_for_wide_part = 1073741824, replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 455451372, compact_parts_max_bytes_to_buffer = 497525557, compact_parts_max_granules_to_buffer = 204, compact_parts_merge_max_bytes_to_prefetch_part = 19847878, merge_max_block_size = 24514, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, concurrent_part_removal_threshold = 23, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 79915, primary_key_compress_block_size = 24139. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:12.933459 [ 22188 ] {25f369b4-d053-43c0-9852-d08840bcb27e} executeQuery: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_1.test_bm' failed: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=3, jobs=3): Cannot attach table `test_1`.`test_bm` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/test_bm.sql from query ATTACH TABLE test_1.test_bm UUID '4108c352-6764-4c19-8931-29486ba17e21' (`dim` UInt64, `id` UInt64) ENGINE = MergeTree ORDER BY (dim, id) SETTINGS index_granularity = 8192, min_bytes_for_wide_part = 92543720, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 7, min_bytes_for_full_part_storage = 33377119, compact_parts_max_bytes_to_buffer = 427964698, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8087794, merge_max_block_size = 20924, old_parts_lifetime = 373., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 2868800162, index_granularity_bytes = 23287569, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 74180, primary_key_compress_block_size = 85331. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10544.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59204) (comment: 01160_table_dependencies.sh) (in query: attach database test_1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Common/AsyncLoader.cpp:0: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x000000000fcc4e50 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000000fc7efae 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3a3b5 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2042: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a57c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:05:12.936255 [ 22188 ] {25f369b4-d053-43c0-9852-d08840bcb27e} TCPHandler: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_1.test_bm' failed: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=3, jobs=3): Cannot attach table `test_1`.`test_bm` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/test_bm.sql from query ATTACH TABLE test_1.test_bm UUID '4108c352-6764-4c19-8931-29486ba17e21' (`dim` UInt64, `id` UInt64) ENGINE = MergeTree ORDER BY (dim, id) SETTINGS index_granularity = 8192, min_bytes_for_wide_part = 92543720, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 7, min_bytes_for_full_part_storage = 33377119, compact_parts_max_bytes_to_buffer = 427964698, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 8087794, merge_max_block_size = 20924, old_parts_lifetime = 373., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 2868800162, index_granularity_bytes = 23287569, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 74180, primary_key_compress_block_size = 85331. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 22. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10544.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Common/AsyncLoader.cpp:0: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x000000000fcc4e50 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000000fc7efae 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3a3b5 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2042: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a57c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:05:13.488468 [ 22188 ] {1cb29f7f-2e85-4127-859b-fc00b99f467e} executeQuery: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59224) (comment: 01160_table_dependencies.sh) (in query: detach database test_1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001769c8cf 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c78608 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:05:13.490058 [ 22188 ] {1cb29f7f-2e85-4127-859b-fc00b99f467e} TCPHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000001769c8cf 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c78608 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:05:14.264273 [ 10932 ] {1da84e60-9044-4e3b-a118-087a8f12fabf} TablesLoader: Tables test_1.dist_01247 depend on default.number, but seems like that does not exist. Will ignore it and try to load existing tables 2025.10.24 00:05:14.557456 [ 23319 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3): Cannot attach table `test_1`.`async_inserts` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/async_inserts.sql from query ATTACH TABLE test_1.async_inserts UUID '280da388-a196-423d-b5a5-866cba0085a6' (`id` UInt32, `s` String) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 8192. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199c2371 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c5d03 10. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 14. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 15. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:14.902295 [ 10932 ] {1da84e60-9044-4e3b-a118-087a8f12fabf} virtual void DB::StorageBuffer::flushAndPrepareForShutdown(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1dfa7 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageBuffer::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000195f1bd0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::StorageBuffer::flushAndPrepareForShutdown() @ 0x00000000195f19f7 11. ./src/Storages/IStorage.h:594: DB::DatabaseWithOwnTablesBase::shutdown() @ 0x0000000017136bea 12. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:184: DB::DatabaseOnDisk::shutdown() @ 0x000000001709b0eb 13. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:606: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769adf1 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:380: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3bab5 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2042: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a57c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:14.985480 [ 10932 ] {1da84e60-9044-4e3b-a118-087a8f12fabf} executeQuery: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_1.async_inserts' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3): Cannot attach table `test_1`.`async_inserts` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/async_inserts.sql from query ATTACH TABLE test_1.async_inserts UUID '280da388-a196-423d-b5a5-866cba0085a6' (`id` UInt32, `s` String) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 8192. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199c2371 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c5d03 10. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 14. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 15. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10544.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:59238) (comment: 01160_table_dependencies.sh) (in query: attach database test_1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Common/AsyncLoader.cpp:0: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x000000000fcc4e50 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000000fc7efae 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3a3b5 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2042: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a57c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:05:14.987441 [ 10932 ] {1da84e60-9044-4e3b-a118-087a8f12fabf} TCPHandler: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'load table test_1.async_inserts' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3): Cannot attach table `test_1`.`async_inserts` from metadata file /var/lib/clickhouse/store/c2b/c2b65cef-c457-423c-9d4a-9ead7b3d8621/async_inserts.sql from query ATTACH TABLE test_1.async_inserts UUID '280da388-a196-423d-b5a5-866cba0085a6' (`id` UInt32, `s` String) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 8192. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199c2371 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c5d03 10. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 14. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 15. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:0: DB::createTableFromAST(DB::ASTCreateQuery, String const&, String const&, std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x000000001709a08f 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::DatabaseOrdinary::loadTableFromMetadata(std::shared_ptr, String const&, DB::QualifiedTableName const&, std::shared_ptr const&, DB::LoadingStrictnessLevel) @ 0x00000000170c9c29 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000170d3ece 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fcc8d67 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fcc9b13 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10544.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Common/AsyncLoader.cpp:0: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x000000000fcc4e50 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000000fc7efae 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:369: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c3a3b5 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2042: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a57c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:05:15.848007 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:15.853347 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:16.267037 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:16.297603 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:16.674589 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:16.705414 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:17.090628 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:17.121506 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:17.541187 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:17.574072 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:17.818091 [ 16195 ] {} ExternalDictionariesLoader: Could not update external dictionary '4d942a90-5124-4d50-8e84-011027e2fc87', leaving the previous version, next update is scheduled at 2025-10-24 00:05:23: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bfc297 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000019bfd21f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000017028d42 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f581e4 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019bf9bd6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bf97d5 16. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x0000000019abec34 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aba072 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c63e3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a30a201 30. ./build_docker/./src/Dictionaries/DictionaryPipelineExecutor.cpp:0: DB::DictionaryPipelineExecutor::pull(DB::Block&) @ 0x000000000ff54611 31. DB::FlatDictionary::loadData() @ 0x000000000ff59b6b (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:17.972756 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:18.004246 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:18.513511 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:18.560938 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:18.991463 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:19.063099 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:19.476857 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:19.509760 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:19.902594 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:19.964208 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:20.378171 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:20.439447 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:20.861811 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:20.895205 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:21.305540 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:21.337055 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:21.787554 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:21.833862 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:22.257844 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:22.287928 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:22.669183 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:22.702217 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:23.101121 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:23.145240 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:23.530740 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:23.562355 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:24.102546 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:24.237125 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:24.670415 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:24.736197 [ 22371 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:25.165882 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:25.199567 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:25.612685 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:25.643312 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:26.057575 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:26.091012 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:26.468649 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:26.499861 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:26.913918 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:26.945930 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:27.409826 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:27.456108 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:27.871721 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:27.903555 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:28.423197 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:28.472960 [ 22188 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:28.906103 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:28.936662 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:29.064875 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:32.029629 [ 2836 ] {} RefreshTask: Refresh view test_13.e failed (attempt 1/1): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 15. ./src/Interpreters/InterpreterCreateQuery.h:29: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x0000000017c5085a 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1535: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4da81 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 18. ./build_docker/./src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x00000000192bab92 19. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:380: DB::RefreshTask::executeRefreshUnlocked(bool) @ 0x0000000019ff6028 20. ./contrib/llvm-project/libcxx/include/__mutex_base:207: DB::RefreshTask::refreshTask() @ 0x0000000019ff46e8 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019ff7522 22. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 24. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:34.030603 [ 2815 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:40.753496 [ 3310 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6e0ce121-7b71-4e14-a14f-c7c363eaab4f::202510_306_311_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:47.009860 [ 3030 ] {} RefreshTask: Refresh view test_13.e failed (attempt 1/1): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 15. ./src/Interpreters/InterpreterCreateQuery.h:29: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x0000000017c5085a 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1535: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4da81 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 18. ./build_docker/./src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x00000000192bab92 19. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:380: DB::RefreshTask::executeRefreshUnlocked(bool) @ 0x0000000019ff6028 20. ./contrib/llvm-project/libcxx/include/__mutex_base:207: DB::RefreshTask::refreshTask() @ 0x0000000019ff46e8 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019ff7522 22. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 24. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:48.058074 [ 3005 ] {} RefreshTask: Refresh view test_13.e failed (attempt 1/1): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 15. ./src/Interpreters/InterpreterCreateQuery.h:29: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x0000000017c5085a 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1535: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4da81 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 18. ./build_docker/./src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x00000000192bab92 19. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:380: DB::RefreshTask::executeRefreshUnlocked(bool) @ 0x0000000019ff6028 20. ./contrib/llvm-project/libcxx/include/__mutex_base:207: DB::RefreshTask::refreshTask() @ 0x0000000019ff46e8 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019ff7522 22. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 24. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:05:52.704954 [ 3315 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {33fe57df-80c6-4d43-85df-8cc2405b55d8::202510_136_141_1}: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fa36f06 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000000fa34b23 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000000f9c38f7 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000000fa6ada2 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x0000000019ea2870 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b2a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:01.688350 [ 3308 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6e0ce121-7b71-4e14-a14f-c7c363eaab4f::202510_306_316_2}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:03.033005 [ 16195 ] {} ExternalDictionariesLoader: Could not update external dictionary '4d942a90-5124-4d50-8e84-011027e2fc87', leaving the previous version, next update is scheduled at 2025-10-24 00:06:08: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=0): (while reading column second_column): (while reading from part /var/lib/clickhouse/store/847/8471dccc-d02b-4a9b-be32-a2c153b48d95/all_1_1_0/ in table database_for_dict.table_for_dict (8471dccc-d02b-4a9b-be32-a2c153b48d95) located on disk default of type local, from mark 0 with max_rows_to_read = 100): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000016d64235 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d65c54 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d661ce 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fe0f1e 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f58c32 18. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:0: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000001702b604 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x0000000019bfbc4a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bfb20e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a98c8ea 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 28. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 29. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:07.017112 [ 3035 ] {} RefreshTask: Refresh view test_13.e failed (attempt 1/1): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 15. ./src/Interpreters/InterpreterCreateQuery.h:29: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x0000000017c5085a 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1535: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4da81 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 18. ./build_docker/./src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x00000000192bab92 19. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:380: DB::RefreshTask::executeRefreshUnlocked(bool) @ 0x0000000019ff6028 20. ./contrib/llvm-project/libcxx/include/__mutex_base:207: DB::RefreshTask::refreshTask() @ 0x0000000019ff46e8 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019ff7522 22. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 24. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:23.023119 [ 3147 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:30.460555 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:30.497044 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:30.915503 [ 22371 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:30.949273 [ 22371 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:31.473235 [ 22371 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:31.524359 [ 22371 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:31.994304 [ 22371 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:32.103962 [ 22371 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:34.133423 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:34.166418 [ 22371 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:34.631502 [ 22371 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:34.666334 [ 22371 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:35.114204 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:35.241622 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:36.124422 [ 22371 ] {ef03a120-7404-4249-af48-0dbb692429c2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=746). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57684) (comment: 01213_alter_rename_column_zookeeper_long.sh) (in query: SELECT name FROM system.columns WHERE name = 'renamed_value1' and table = 'table_for_rename_replicated' AND database = 'test_13'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:06:36.126462 [ 22371 ] {ef03a120-7404-4249-af48-0dbb692429c2} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=746). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:06:37.278725 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:37.332135 [ 22371 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:37.765453 [ 22371 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:37.801700 [ 22371 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:37.827825 [ 18285 ] {2ae9017d-f6e7-4aa5-b7cd-c98dfddf35f4} executeQuery: Code: 410. DB::Exception: BridgeHelper: clickhouse-odbc-bridge is not responding. (EXTERNAL_SERVER_IS_NOT_RESPONDING) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:37398) (comment: 01086_odbc_roundtrip.sh) (in query: select count() > 1 as ok from (select * from odbc('DSN={ClickHouse DSN (ANSI)}','system','tables'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/BridgeHelper/IBridgeHelper.cpp:0: DB::IBridgeHelper::startBridgeSync() @ 0x000000001a0d9a59 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::ITableFunctionXDBC::startBridgeIfNot(std::shared_ptr) const @ 0x0000000015ea5d74 6. ./build_docker/./src/TableFunctions/ITableFunctionXDBC.cpp:0: DB::(anonymous namespace)::ITableFunctionXDBC::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015ea567d 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 8. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1bbd 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d690b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:06:37.830448 [ 18285 ] {2ae9017d-f6e7-4aa5-b7cd-c98dfddf35f4} TCPHandler: Code: 410. DB::Exception: BridgeHelper: clickhouse-odbc-bridge is not responding. (EXTERNAL_SERVER_IS_NOT_RESPONDING), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/BridgeHelper/IBridgeHelper.cpp:0: DB::IBridgeHelper::startBridgeSync() @ 0x000000001a0d9a59 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::ITableFunctionXDBC::startBridgeIfNot(std::shared_ptr) const @ 0x0000000015ea5d74 6. ./build_docker/./src/TableFunctions/ITableFunctionXDBC.cpp:0: DB::(anonymous namespace)::ITableFunctionXDBC::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015ea567d 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 8. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1bbd 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d690b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:06:38.173980 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:38.233554 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:40.285731 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:40.295643 [ 30738 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:40.703060 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:40.733858 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:41.148491 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:41.181671 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:41.570300 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:41.601496 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:42.071163 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:42.081258 [ 18285 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:42.501889 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:42.534703 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:43.500310 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:43.531093 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:43.920095 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:43.952920 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:44.350456 [ 18285 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:44.383365 [ 18285 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:44.766356 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:44.803519 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:45.179903 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:45.213526 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:45.590991 [ 18285 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:45.621100 [ 18285 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:46.005083 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:46.036727 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:46.495967 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:46.527779 [ 18285 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:46.536899 [ 18285 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:47.036415 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:47.084129 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:47.512299 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:47.551474 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:47.795950 [ 21666 ] {29442561-0afd-4832-a15b-fa98ace9ceda} DynamicQueryHandler: Code: 271. DB::Exception: Invalid zero byte count(s): 5 and 1. (CANNOT_DECOMPRESS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, unsigned int&) @ 0x00000000135d9d26 4. ./build_docker/./src/Compression/CompressionCodecFPC.cpp:0: DB::CompressionCodecFPC::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x0000000016db99c7 5. ./build_docker/./src/Compression/ICompressionCodec.cpp:110: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x0000000016dc8710 6. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:318: DB::CompressedReadBufferBase::decompress(DB::BufferBase::Buffer&, unsigned long, unsigned long) @ 0x0000000016d6490d 7. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:13: non-virtual thunk to DB::CompressedReadBuffer::nextImpl() @ 0x0000000016d62836 8. DB::ReadBuffer::next() @ 0x0000000007b3717b 9. ./build_docker/./src/IO/ReadBuffer.cpp:0: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000001659579b 10. DB::ReadBuffer::next() @ 0x0000000007b3717b 11. ./src/IO/ConcatReadBuffer.h:0: DB::ConcatReadBuffer::nextImpl() @ 0x0000000017567677 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./src/IO/ReadBuffer.h:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224a08 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 15. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:47.902030 [ 21666 ] {f115a1a3-1c97-48cb-a683-026f7ea0ccee} DynamicQueryHandler: Code: 271. DB::Exception: Invalid zero byte count(s): 1 and 6. (CANNOT_DECOMPRESS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, unsigned int&) @ 0x00000000135d9d26 4. ./build_docker/./src/Compression/CompressionCodecFPC.cpp:0: DB::CompressionCodecFPC::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x0000000016db99c7 5. ./build_docker/./src/Compression/ICompressionCodec.cpp:110: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x0000000016dc8710 6. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:318: DB::CompressedReadBufferBase::decompress(DB::BufferBase::Buffer&, unsigned long, unsigned long) @ 0x0000000016d6490d 7. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:13: non-virtual thunk to DB::CompressedReadBuffer::nextImpl() @ 0x0000000016d62836 8. DB::ReadBuffer::next() @ 0x0000000007b3717b 9. ./build_docker/./src/IO/ReadBuffer.cpp:0: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x000000001659579b 10. DB::ReadBuffer::next() @ 0x0000000007b3717b 11. ./src/IO/ConcatReadBuffer.h:0: DB::ConcatReadBuffer::nextImpl() @ 0x0000000017567677 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./src/IO/ReadBuffer.h:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224a08 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 15. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 16. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:48.008587 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:48.140140 [ 10932 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:48.647610 [ 30738 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:48.681440 [ 30738 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:48.690702 [ 30738 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:49.159314 [ 18285 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:49.192511 [ 18285 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:49.711241 [ 30738 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:49.768697 [ 30738 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:50.217276 [ 18285 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:50.250615 [ 18285 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:50.672437 [ 18285 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:06:50.706231 [ 18285 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_1 does not exist. Maybe you meant test_13?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x000000001769a266 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabase(String const&) @ 0x00000000175b6f18 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000001a1ee9a5 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 11. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007f7c69445ac3 15. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:07:06.022157 [ 3089 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:07:06.870474 [ 10932 ] {17fee0d8-0950-48e0-835f-8b46757863a2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=0): (while reading column x): (while reading from part /var/lib/clickhouse/store/254/25492b42-8a7f-4082-a96a-97fcaf37985b/20251023_20251023_1_5_1/ in table test_8oc9ggpo.summing_merge_tree_aggregate_function (25492b42-8a7f-4082-a96a-97fcaf37985b) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:43394) (comment: 00148_summing_merge_tree_aggregate_function.sql) (in query: select k, sum(c), topKMerge(2)(x) from summing_merge_tree_aggregate_function group by k;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b69ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d63132 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d65385 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d655fe 17. DB::ReadBuffer::next() @ 0x0000000007b3717b 18. ./src/IO/ReadBuffer.h:106: DB::SerializationAggregateFunction::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016f6161a 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f58c32 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bcd448 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bee90e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a98c8ea 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 29. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 30. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 2025.10.24 00:07:06.874240 [ 10932 ] {17fee0d8-0950-48e0-835f-8b46757863a2} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=0): (while reading column x): (while reading from part /var/lib/clickhouse/store/254/25492b42-8a7f-4082-a96a-97fcaf37985b/20251023_20251023_1_5_1/ in table test_8oc9ggpo.summing_merge_tree_aggregate_function (25492b42-8a7f-4082-a96a-97fcaf37985b) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x0000000007b69ee3 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:198: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d63132 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d65385 16. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d655fe 17. DB::ReadBuffer::next() @ 0x0000000007b3717b 18. ./src/IO/ReadBuffer.h:106: DB::SerializationAggregateFunction::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016f6161a 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f58c32 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x0000000019bcd448 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:0: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bee90e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a98c8ea 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 29. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 30. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 2025.10.24 00:07:06.987304 [ 21666 ] {41a6e7b1-b942-42cc-8be9-ee047b721631} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:40488) (comment: 00148_summing_merge_tree_aggregate_function.sql) (in query: DROP DATABASE IF EXISTS test_8oc9ggpo ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:07:06.988376 [ 21666 ] {41a6e7b1-b942-42cc-8be9-ee047b721631} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:07:07.000526 [ 18285 ] {a5428926-c750-482b-9f3f-22db1fa505ba} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:40502) (comment: 00148_summing_merge_tree_aggregate_function.sql) (in query: DROP DATABASE IF EXISTS test_8oc9ggpo ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:07:07.090733 [ 18285 ] {a5428926-c750-482b-9f3f-22db1fa505ba} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:07:07.107910 [ 30738 ] {4db440ba-9b87-44ae-909b-7d42b97d4efc} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:40510) (comment: 00148_summing_merge_tree_aggregate_function.sql) (in query: DROP DATABASE IF EXISTS test_8oc9ggpo ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:07:07.109732 [ 30738 ] {4db440ba-9b87-44ae-909b-7d42b97d4efc} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:07:08.328575 [ 3513 ] {} ExternalDictionariesLoader: Could not update external dictionary '4d942a90-5124-4d50-8e84-011027e2fc87', leaving the previous version, next update is scheduled at 2025-10-24 00:07:13: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bfc297 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000019bfd21f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f57e90 13. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:0: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000170291cf 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f581e4 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019bf9bd6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bf97d5 17. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x0000000019abec34 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aba072 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c63e3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 25. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 26. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a30a201 31. ./build_docker/./src/Dictionaries/DictionaryPipelineExecutor.cpp:0: DB::DictionaryPipelineExecutor::pull(DB::Block&) @ 0x000000000ff54611 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:07:11.831089 [ 10932 ] {56988eb1-4fa8-4ed5-b387-2690f58a7302} executeQuery: Code: 80. DB::Exception: Create table with statistics is now disabled. Turn on allow_experimental_statistics. (INCORRECT_QUERY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:42524) (comment: 02864_statistics_ddl.sql) (in query: -- Error case: Can't create statistics when allow_experimental_statistics = 0 CREATE TABLE tab (col Float64 STATISTICS(tdigest)) Engine = MergeTree() ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000017c41ce6 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c427d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4d006 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:07:11.832249 [ 10932 ] {56988eb1-4fa8-4ed5-b387-2690f58a7302} TCPHandler: Code: 80. DB::Exception: Create table with statistics is now disabled. Turn on allow_experimental_statistics. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000017c41ce6 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c427d6 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4d006 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:07:12.213022 [ 10932 ] {4c56bf7d-9931-4325-81e0-128b9c2b1ce5} executeQuery: Code: 80. DB::Exception: Unknown statistics type: no_statistics_type. Supported statistics types are 'tdigest', 'uniq' and 'count_min'. (INCORRECT_QUERY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:42524) (comment: 02864_statistics_ddl.sql) (in query: -- Error case: Unknown statistics types are rejected CREATE TABLE tab (col Float64 STATISTICS(no_statistics_type)) Engine = MergeTree() ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Storages/StatisticsDescription.cpp:54: DB::stringToStatisticsType(String) @ 0x000000001917f4f5 5. ./build_docker/./src/Storages/StatisticsDescription.cpp:183: DB::ColumnStatisticsDescription::fromColumnDeclaration(DB::ASTColumnDeclaration const&, std::shared_ptr) @ 0x0000000019181339 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000017c414b4 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c427d6 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4d006 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:07:12.214146 [ 10932 ] {4c56bf7d-9931-4325-81e0-128b9c2b1ce5} TCPHandler: Code: 80. DB::Exception: Unknown statistics type: no_statistics_type. Supported statistics types are 'tdigest', 'uniq' and 'count_min'. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Storages/StatisticsDescription.cpp:54: DB::stringToStatisticsType(String) @ 0x000000001917f4f5 5. ./build_docker/./src/Storages/StatisticsDescription.cpp:183: DB::ColumnStatisticsDescription::fromColumnDeclaration(DB::ASTColumnDeclaration const&, std::shared_ptr) @ 0x0000000019181339 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000017c414b4 7. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c427d6 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4d006 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:07:12.503126 [ 10932 ] {a980c05b-3016-489f-9ba9-2cddfc8a6a1a} executeQuery: Code: 80. DB::Exception: Column col already contains statistics type tdigest. (INCORRECT_QUERY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:42524) (comment: 02864_statistics_ddl.sql) (in query: -- Error case: The same statistics type can't exist more than once on a column CREATE TABLE tab (col Float64 STATISTICS(tdigest, tdigest)) Engine = MergeTree() ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x000000000fca2c86 4. ./build_docker/./src/Storages/StatisticsDescription.cpp:185: DB::ColumnStatisticsDescription::fromColumnDeclaration(DB::ASTColumnDeclaration const&, std::shared_ptr) @ 0x0000000019181767 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000017c414b4 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c427d6 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4d006 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:07:12.504917 [ 10932 ] {a980c05b-3016-489f-9ba9-2cddfc8a6a1a} TCPHandler: Code: 80. DB::Exception: Column col already contains statistics type tdigest. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x000000000fca2c86 4. ./build_docker/./src/Storages/StatisticsDescription.cpp:185: DB::ColumnStatisticsDescription::fromColumnDeclaration(DB::ASTColumnDeclaration const&, std::shared_ptr) @ 0x0000000019181767 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000017c414b4 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c427d6 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4d006 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:07:13.002483 [ 10932 ] {911e2aa1-d31a-485c-9d62-cb0a16e5e614} executeQuery: Code: 57. DB::Exception: Table test_9q5qtimy.tab already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:42524) (comment: 02864_statistics_ddl.sql) (in query: CREATE TABLE tab (col Date STATISTICS(tdigest)) Engine = MergeTree() ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.24 00:07:13.004152 [ 10932 ] {911e2aa1-d31a-485c-9d62-cb0a16e5e614} TCPHandler: Code: 57. DB::Exception: Table test_9q5qtimy.tab already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.24 00:07:13.107238 [ 18285 ] {13d7579a-f53e-4ebd-9e6a-7c64127a5bed} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50358) (comment: 02864_statistics_ddl.sql) (in query: DROP DATABASE IF EXISTS test_9q5qtimy ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:07:13.108380 [ 18285 ] {13d7579a-f53e-4ebd-9e6a-7c64127a5bed} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:07:13.122695 [ 30738 ] {a8aa1a2f-3d7d-41cc-8b70-7d3954c26395} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50364) (comment: 02864_statistics_ddl.sql) (in query: DROP DATABASE IF EXISTS test_9q5qtimy ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:07:13.124539 [ 30738 ] {a8aa1a2f-3d7d-41cc-8b70-7d3954c26395} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:07:13.138744 [ 18285 ] {86759b86-faa2-4070-a2ea-758f83419720} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50376) (comment: 02864_statistics_ddl.sql) (in query: DROP DATABASE IF EXISTS test_9q5qtimy ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:07:13.141393 [ 18285 ] {86759b86-faa2-4070-a2ea-758f83419720} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:07:13.158759 [ 30738 ] {60d1c594-1493-40f8-99e5-d34e9a4294fa} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:50378) (comment: 02864_statistics_ddl.sql) (in query: DROP DATABASE IF EXISTS test_9q5qtimy ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:07:13.160337 [ 30738 ] {60d1c594-1493-40f8-99e5-d34e9a4294fa} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:07:15.546016 [ 30738 ] {8b15e4b7-d0c7-4d78-875c-c242f6b3489c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:42548) (comment: 01135_default_and_alter_zookeeper.sql) (in query: ATTACH TABLE default_table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199c2371 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c5d03 10. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000019341fd0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000019e4f587 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a2e3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 14. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.24 00:07:15.548485 [ 30738 ] {8b15e4b7-d0c7-4d78-875c-c242f6b3489c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000199c2371 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c5d03 10. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x0000000019341fd0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x0000000019e4f587 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a2e3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 14. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.24 00:07:20.696552 [ 30738 ] {09086ba0-4ca2-4d05-9f5a-2a1c40c21eea} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57090) (comment: 01545_system_errors.sh) (in query: SELECT throwIf(1)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e3dd96c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.24 00:07:20.697614 [ 30738 ] {09086ba0-4ca2-4d05-9f5a-2a1c40c21eea} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e3dd96c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.24 00:07:23.020274 [ 2740 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:07:23.028692 [ 10932 ] {a2b45fc9-6ba5-47b5-be8a-fbd1717408be} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(not(__table1.dummy) :: 2) -> throwIf(not(__table1.dummy)) UInt8 : 0'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10544.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:36212) (comment: 01545_system_errors.sh) (in query: SELECT `__table1`.`dummy` AS `dummy` FROM `system`.`one` AS `__table1` WHERE throwIf(NOT `__table1`.`dummy`)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e3dd96c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 10. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001a6ad090 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:119: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001a6acef7 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.24 00:07:23.030732 [ 10932 ] {a2b45fc9-6ba5-47b5-be8a-fbd1717408be} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(not(__table1.dummy) :: 2) -> throwIf(not(__table1.dummy)) UInt8 : 0'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e3dd96c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 10. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001a6ad090 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:119: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001a6acef7 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 2025.10.24 00:07:23.044828 [ 30738 ] {01cdc2fc-a897-484d-a8d3-404df7059724} executeQuery: Code: 395. DB::Exception: Received from 127.2:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(not(__table1.dummy) :: 2) -> throwIf(not(__table1.dummy)) UInt8 : 0'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e3dd96c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 10. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001a6ad090 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:119: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001a6acef7 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57148) (comment: 01545_system_errors.sh) (in query: SELECT * FROM remote('127.2', system.one) where throwIf(not dummy)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000faa1a74 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a058f02 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a063254 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0c20fe 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e35bdf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e356e0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e34243 2025.10.24 00:07:23.047195 [ 30738 ] {01cdc2fc-a897-484d-a8d3-404df7059724} TCPHandler: Code: 395. DB::Exception: Received from 127.2:9000. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(not(__table1.dummy) :: 2) -> throwIf(not(__table1.dummy)) UInt8 : 0'. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e3dd96c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000076369bc 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 10. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000001a6ad090 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:119: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000001a6acef7 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 18. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 21. __tsan_thread_start_func @ 0x000000000758df2f 22. ? @ 0x00007f7c69445ac3 23. ? @ 0x00007f7c694d7850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000faa1a74 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000001a058f02 4. ./build_docker/./src/Client/Connection.cpp:1229: DB::Connection::receivePacket() @ 0x000000001a063254 5. ./build_docker/./src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000001a0c20fe 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e35bdf 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000016e356e0 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x0000000016e34243 2025.10.24 00:07:28.289726 [ 11319 ] {} ExternalDictionariesLoader: Could not update external dictionary '4d942a90-5124-4d50-8e84-011027e2fc87', leaving the previous version, next update is scheduled at 2025-10-24 00:07:33: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bfc297 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000019bfd21f 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000017028d42 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f581e4 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019bf9bd6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bf97d5 16. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x0000000019abec34 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aba072 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c63e3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a30a201 30. ./build_docker/./src/Dictionaries/DictionaryPipelineExecutor.cpp:0: DB::DictionaryPipelineExecutor::pull(DB::Block&) @ 0x000000000ff54611 31. DB::FlatDictionary::loadData() @ 0x000000000ff59b6b (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:07:31.019451 [ 3043 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:07:31.829831 [ 10932 ] {60da68db-4367-47a8-9abb-31c9211e7602} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=746). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:54462) (comment: 01066_bit_count.sql) (in query: SELECT x, bitCount(x), hex(reinterpretAsString(x)) FROM VALUES ('x Float64', (1), (-1), (inf));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:07:31.831724 [ 10932 ] {60da68db-4367-47a8-9abb-31c9211e7602} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=746). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:07:48.022285 [ 3223 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:07:53.446044 [ 30738 ] {e34b089e-859f-417a-8b33-d5af51b82e6f} executeQuery: Code: 660. DB::Exception: Unable to connect to HDFS: Hdfs::HdfsRpcException: HdfsFailoverException: Failed to invoke RPC call "getFsStats" on server "localhost:12222" Caused by: HdfsNetworkConnectException: Connect to "localhost:12222" failed: (errno: 111) Connection refused. (HDFS_ERROR) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:54472) (comment: 02536_hdfs_cluster_use_structure_from_table.sql) (in query: insert into table function hdfs('hdfs://localhost:12222/test_02536.jsonl', 'TSV') select '{"x" : {"a" : 1, "b" : 2}}' settings hdfs_truncate_on_insert=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Storages/ObjectStorage/HDFS/HDFSCommon.cpp:0: DB::createHDFSFS(hdfsBuilder*) @ 0x00000000163eeb58 5. ./build_docker/./src/Disks/ObjectStorages/HDFS/HDFSObjectStorage.cpp:35: DB::HDFSObjectStorage::initializeHDFSFS() const @ 0x00000000165c83f5 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::HDFSObjectStorage::writeObject(DB::StoredObject const&, DB::WriteMode, std::optional, std::allocator>>>, unsigned long, DB::WriteSettings const&) @ 0x00000000165ca2a2 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:0: DB::StorageObjectStorageSink::StorageObjectStorageSink(std::shared_ptr, std::shared_ptr, std::optional const&, DB::Block const&, std::shared_ptr, String const&) @ 0x0000000016387a69 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageObjectStorageSink* std::construct_at[abi:v15007] const&, std::shared_ptr, std::optional const&, DB::Block const&, std::shared_ptr&, DB::StorageObjectStorageSink*>(DB::StorageObjectStorageSink*, std::shared_ptr const&, std::shared_ptr&&, std::optional const&, DB::Block const&, std::shared_ptr&) @ 0x000000001638062b 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:0: DB::StorageObjectStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000016379523 10. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a79ae1d 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000017d48f54 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d49eb8 13. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4c3d4 14. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f801 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.24 00:07:53.448694 [ 30738 ] {e34b089e-859f-417a-8b33-d5af51b82e6f} TCPHandler: Code: 660. DB::Exception: Unable to connect to HDFS: Hdfs::HdfsRpcException: HdfsFailoverException: Failed to invoke RPC call "getFsStats" on server "localhost:12222" Caused by: HdfsNetworkConnectException: Connect to "localhost:12222" failed: (errno: 111) Connection refused. (HDFS_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Storages/ObjectStorage/HDFS/HDFSCommon.cpp:0: DB::createHDFSFS(hdfsBuilder*) @ 0x00000000163eeb58 5. ./build_docker/./src/Disks/ObjectStorages/HDFS/HDFSObjectStorage.cpp:35: DB::HDFSObjectStorage::initializeHDFSFS() const @ 0x00000000165c83f5 6. ./contrib/llvm-project/libcxx/include/optional:344: DB::HDFSObjectStorage::writeObject(DB::StoredObject const&, DB::WriteMode, std::optional, std::allocator>>>, unsigned long, DB::WriteSettings const&) @ 0x00000000165ca2a2 7. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSink.cpp:0: DB::StorageObjectStorageSink::StorageObjectStorageSink(std::shared_ptr, std::shared_ptr, std::optional const&, DB::Block const&, std::shared_ptr, String const&) @ 0x0000000016387a69 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageObjectStorageSink* std::construct_at[abi:v15007] const&, std::shared_ptr, std::optional const&, DB::Block const&, std::shared_ptr&, DB::StorageObjectStorageSink*>(DB::StorageObjectStorageSink*, std::shared_ptr const&, std::shared_ptr&&, std::optional const&, DB::Block const&, std::shared_ptr&) @ 0x000000001638062b 9. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:0: DB::StorageObjectStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000016379523 10. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000001a79ae1d 11. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x0000000017d48f54 12. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000017d49eb8 13. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000017d4c3d4 14. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000017d4f801 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.24 00:07:58.333759 [ 11323 ] {} ExternalDictionariesLoader: Could not update external dictionary '4d942a90-5124-4d50-8e84-011027e2fc87', leaving the previous version, next update is scheduled at 2025-10-24 00:08:04: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=0): (while reading column fourth_column): (while reading from part /var/lib/clickhouse/store/847/8471dccc-d02b-4a9b-be32-a2c153b48d95/all_1_1_0/ in table database_for_dict.table_for_dict (8471dccc-d02b-4a9b-be32-a2c153b48d95) located on disk default of type local, from mark 0 with max_rows_to_read = 100): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000016d64235 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d65c54 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d661ce 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016ff348b 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f58c32 18. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:0: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000001702b604 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x0000000019bfbc4a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bfb20e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a98c8ea 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 28. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 29. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:08:00.070091 [ 21666 ] {02cc0a90-a532-498f-a390-5e7d9fb58c1a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=746). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:48994) (comment: 01624_soft_constraints.sh) (in query: SELECT count() FROM hypothesis_test_test WHERE c < a FORMAT JSON), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:08:00.147163 [ 21666 ] {02cc0a90-a532-498f-a390-5e7d9fb58c1a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=746). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:08:01.057046 [ 2996 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:08:08.337853 [ 11309 ] {} ExternalDictionariesLoader: Could not update external dictionary '4d942a90-5124-4d50-8e84-011027e2fc87', leaving the previous version, next update is scheduled at 2025-10-24 00:08:14: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bfc297 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000019bfd21f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f57e90 13. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:0: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000170291cf 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f581e4 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019bf9bd6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bf97d5 17. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x0000000019abec34 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aba072 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c63e3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 25. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 26. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a30a201 31. ./build_docker/./src/Dictionaries/DictionaryPipelineExecutor.cpp:0: DB::DictionaryPipelineExecutor::pull(DB::Block&) @ 0x000000000ff54611 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:08:10.023478 [ 3135 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:08:12.015796 [ 18285 ] {860e6a56-fd2b-4514-be09-9ebe36f70a28} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:39346) (comment: 01624_soft_constraints.sh) (in query: DROP DATABASE IF EXISTS test_hne16puh ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:08:12.017829 [ 18285 ] {860e6a56-fd2b-4514-be09-9ebe36f70a28} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:08:12.029646 [ 10932 ] {adfb4490-584b-4561-9841-6488850b2d9a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:39352) (comment: 01624_soft_constraints.sh) (in query: DROP DATABASE IF EXISTS test_hne16puh ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:08:12.031148 [ 10932 ] {adfb4490-584b-4561-9841-6488850b2d9a} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:08:12.043471 [ 21666 ] {067915c4-3372-4c33-ab95-7ccf5239905b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:39368) (comment: 01624_soft_constraints.sh) (in query: DROP DATABASE IF EXISTS test_hne16puh ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:08:12.044927 [ 21666 ] {067915c4-3372-4c33-ab95-7ccf5239905b} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:08:12.056837 [ 10932 ] {01b14a75-e815-42b9-a04a-8a10b9f54fbc} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:39380) (comment: 01624_soft_constraints.sh) (in query: DROP DATABASE IF EXISTS test_hne16puh ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:08:12.058501 [ 10932 ] {01b14a75-e815-42b9-a04a-8a10b9f54fbc} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:08:12.069286 [ 30738 ] {9f31d33a-0da2-469a-befe-0424d900f8e6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:39384) (comment: 01624_soft_constraints.sh) (in query: DROP DATABASE IF EXISTS test_hne16puh ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:08:12.070568 [ 30738 ] {9f31d33a-0da2-469a-befe-0424d900f8e6} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:08:12.082951 [ 10932 ] {a0d223f2-636f-46e3-bcc8-9d505eaacab9} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:39386) (comment: 01624_soft_constraints.sh) (in query: DROP DATABASE IF EXISTS test_hne16puh ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:08:12.084370 [ 10932 ] {a0d223f2-636f-46e3-bcc8-9d505eaacab9} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:08:12.095147 [ 21666 ] {d609d38e-3aa2-4e72-b4b6-bb62a8f5f4bf} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:39396) (comment: 01624_soft_constraints.sh) (in query: DROP DATABASE IF EXISTS test_hne16puh ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:08:12.096413 [ 21666 ] {d609d38e-3aa2-4e72-b4b6-bb62a8f5f4bf} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:08:14.574554 [ 30738 ] {604d956f-f2a0-4096-877b-ce8f239a7011} executeQuery: Code: 69. DB::Exception: Negative scales and scales larger than precision are not supported. (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36882) (comment: 00700_decimal_bounds.sql) (in query: CREATE TABLE IF NOT EXISTS decimal (x DECIMAL(10, -2)) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./src/DataTypes/DataTypeDecimalBase.h:199: _ZN2DB13createDecimalITtTyENS_15DataTypeDecimalEEENSt3__110shared_ptrIKNS_9IDataTypeEEEmm @ 0x000000001640502a 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:0: DB::create(std::shared_ptr const&) @ 0x0000000016ecaeae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000016e3f8c4 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000016e5a0e7 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:74: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x0000000016e57761 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:558: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000017c3f6ba 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c427d6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4d006 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 2025.10.24 00:08:14.575803 [ 30738 ] {604d956f-f2a0-4096-877b-ce8f239a7011} TCPHandler: Code: 69. DB::Exception: Negative scales and scales larger than precision are not supported. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./src/DataTypes/DataTypeDecimalBase.h:199: _ZN2DB13createDecimalITtTyENS_15DataTypeDecimalEEENSt3__110shared_ptrIKNS_9IDataTypeEEEmm @ 0x000000001640502a 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:0: DB::create(std::shared_ptr const&) @ 0x0000000016ecaeae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000016e3f8c4 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000016e5a0e7 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:74: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x0000000016e57761 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:558: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000017c3f6ba 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c427d6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4d006 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 2025.10.24 00:08:14.659297 [ 30738 ] {22f0af14-5eb2-4073-b46d-500e81244daa} executeQuery: Code: 69. DB::Exception: Negative scales and scales larger than precision are not supported. (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36882) (comment: 00700_decimal_bounds.sql) (in query: CREATE TABLE IF NOT EXISTS decimal (x DECIMAL(10, 15)) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./src/DataTypes/DataTypeDecimalBase.h:199: _ZN2DB13createDecimalITtTyENS_15DataTypeDecimalEEENSt3__110shared_ptrIKNS_9IDataTypeEEEmm @ 0x000000001640502a 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:0: DB::create(std::shared_ptr const&) @ 0x0000000016ecaeae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000016e3f8c4 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000016e5a0e7 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:74: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x0000000016e57761 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:558: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000017c3f6ba 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c427d6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4d006 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 2025.10.24 00:08:14.660640 [ 30738 ] {22f0af14-5eb2-4073-b46d-500e81244daa} TCPHandler: Code: 69. DB::Exception: Negative scales and scales larger than precision are not supported. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./src/DataTypes/DataTypeDecimalBase.h:199: _ZN2DB13createDecimalITtTyENS_15DataTypeDecimalEEENSt3__110shared_ptrIKNS_9IDataTypeEEEmm @ 0x000000001640502a 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:0: DB::create(std::shared_ptr const&) @ 0x0000000016ecaeae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000016e3f8c4 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000016e5a0e7 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:74: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x0000000016e57761 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:558: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000017c3f6ba 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c427d6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4d006 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 2025.10.24 00:08:15.056100 [ 30738 ] {03cce0ae-536d-4eed-9673-1001cd1d2dee} executeQuery: Code: 69. DB::Exception: Wrong precision: it must be between 1 and 76, got 0. (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36882) (comment: 00700_decimal_bounds.sql) (in query: CREATE TABLE IF NOT EXISTS decimal (x DECIMAL(0, 0)) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long const&, unsigned long&) @ 0x00000000164050cc 4. ./src/DataTypes/DataTypeDecimalBase.h:195: _ZN2DB13createDecimalITtTyENS_15DataTypeDecimalEEENSt3__110shared_ptrIKNS_9IDataTypeEEEmm @ 0x0000000016404fb9 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:0: DB::create(std::shared_ptr const&) @ 0x0000000016ecaeae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000016e3f8c4 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000016e5a0e7 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:74: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x0000000016e57761 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:558: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000017c3f6ba 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c427d6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4d006 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 2025.10.24 00:08:15.057075 [ 30738 ] {03cce0ae-536d-4eed-9673-1001cd1d2dee} TCPHandler: Code: 69. DB::Exception: Wrong precision: it must be between 1 and 76, got 0. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long const&, unsigned long&) @ 0x00000000164050cc 4. ./src/DataTypes/DataTypeDecimalBase.h:195: _ZN2DB13createDecimalITtTyENS_15DataTypeDecimalEEENSt3__110shared_ptrIKNS_9IDataTypeEEEmm @ 0x0000000016404fb9 5. ./build_docker/./src/DataTypes/DataTypesDecimal.cpp:0: DB::create(std::shared_ptr const&) @ 0x0000000016ecaeae 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000016e3f8c4 7. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000016e5a0e7 8. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:74: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x0000000016e57761 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:558: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000017c3f6ba 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x0000000017c427d6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4d006 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 22. __tsan_thread_start_func @ 0x000000000758df2f 23. ? @ 0x00007f7c69445ac3 24. ? @ 0x00007f7c694d7850 2025.10.24 00:08:23.441576 [ 18285 ] {2fe7d478-d0f1-4252-9b70-c337b7eab8ea} executeQuery: Code: 174. DB::Exception: Cyclic aliases for identifier 'b'. In scope SELECT a + 1 AS b, b + 1 AS a FROM (SELECT 10 AS a). (CYCLIC_ALIASES) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:41306) (comment: 00818_alias_bug_4110.sql) (in query: select a + 1 as b, b + 1 as a from (select 10 as a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b2b45 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b350f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1fee 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bd4a8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b251c 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b350f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1fee 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bd4a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 2025.10.24 00:08:23.443143 [ 18285 ] {2fe7d478-d0f1-4252-9b70-c337b7eab8ea} TCPHandler: Code: 174. DB::Exception: Cyclic aliases for identifier 'b'. In scope SELECT a + 1 AS b, b + 1 AS a FROM (SELECT 10 AS a). (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x00000000082f1e86 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b2b45 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b350f 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1fee 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bd4a8 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b251c 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1388: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x00000000174b350f 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1fee 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bd4a8 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 2025.10.24 00:08:23.455516 [ 18285 ] {376f35bf-be93-4d01-80ef-69314bafca0f} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'a' in scope SELECT 10 AS a, a + 1 AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:41306) (comment: 00818_alias_bug_4110.sql) (in query: select 10 as a, a + 1 as a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bd4a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.24 00:08:23.456554 [ 18285 ] {376f35bf-be93-4d01-80ef-69314bafca0f} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'a' in scope SELECT 10 AS a, a + 1 AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bd4a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.24 00:08:23.467955 [ 18285 ] {e2a9c5f1-c4fe-49eb-9678-32dab32c6c3c} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'a' in scope WITH 10 AS a SELECT a AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:41306) (comment: 00818_alias_bug_4110.sql) (in query: with 10 as a select a as a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.24 00:08:23.468966 [ 18285 ] {e2a9c5f1-c4fe-49eb-9678-32dab32c6c3c} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'a' in scope WITH 10 AS a SELECT a AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 24. __tsan_thread_start_func @ 0x000000000758df2f 25. ? @ 0x00007f7c69445ac3 26. ? @ 0x00007f7c694d7850 2025.10.24 00:08:23.480362 [ 18285 ] {3d0e9bb3-656a-4aca-b97a-9ac9460db68a} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'a' in scope WITH 10 AS a SELECT a + 1 AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:41306) (comment: 00818_alias_bug_4110.sql) (in query: with 10 as a select a + 1 as a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bd4a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.24 00:08:23.481372 [ 18285 ] {3d0e9bb3-656a-4aca-b97a-9ac9460db68a} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'a' in scope WITH 10 AS a SELECT a + 1 AS a. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000174de63c 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a3f7f 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174bd4a8 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 25. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 2025.10.24 00:08:23.874641 [ 21666 ] {49d9ef52-5129-4a70-a5f9-51649c4ac881} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:51734) (comment: 00818_alias_bug_4110.sql) (in query: DROP DATABASE IF EXISTS test_m84amvcs ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:08:23.976685 [ 21666 ] {49d9ef52-5129-4a70-a5f9-51649c4ac881} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:08:23.988324 [ 18285 ] {ed62fc15-1546-4738-a3fb-28aa83f4b55f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:51748) (comment: 00818_alias_bug_4110.sql) (in query: DROP DATABASE IF EXISTS test_m84amvcs ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:08:23.989632 [ 18285 ] {ed62fc15-1546-4738-a3fb-28aa83f4b55f} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:08:24.002080 [ 21666 ] {4cb973c0-e39d-494b-8f7e-2e44e0359a59} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:51750) (comment: 00818_alias_bug_4110.sql) (in query: DROP DATABASE IF EXISTS test_m84amvcs ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:08:24.077831 [ 21666 ] {4cb973c0-e39d-494b-8f7e-2e44e0359a59} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:08:24.090977 [ 18285 ] {6ec0a814-78be-43fe-9149-c260f3e89612} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:51756) (comment: 00818_alias_bug_4110.sql) (in query: DROP DATABASE IF EXISTS test_m84amvcs ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:08:24.092666 [ 18285 ] {6ec0a814-78be-43fe-9149-c260f3e89612} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:08:31.226383 [ 3315 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {34e0b00e-fe5a-47d8-af0c-3ae1d30a34d1::202510_204_209_1}: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fa36f06 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000000fa34b23 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000000f9c38f7 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000000fa6ada2 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x0000000019ea2870 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b2a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:08:33.560540 [ 22371 ] {f01e021e-1b6f-4403-842b-b921b8ec88e0} executeQuery: Code: 410. DB::Exception: BridgeHelper: clickhouse-odbc-bridge is not responding. (EXTERNAL_SERVER_IS_NOT_RESPONDING) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57760) (comment: 01086_odbc_roundtrip.sh) (in query: select count() > 1 as ok from (select * from odbc('DSN={ClickHouse DSN (ANSI)}','system','tables'))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/BridgeHelper/IBridgeHelper.cpp:0: DB::IBridgeHelper::startBridgeSync() @ 0x000000001a0d9a59 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::ITableFunctionXDBC::startBridgeIfNot(std::shared_ptr) const @ 0x0000000015ea5d74 6. ./build_docker/./src/TableFunctions/ITableFunctionXDBC.cpp:0: DB::(anonymous namespace)::ITableFunctionXDBC::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015ea567d 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 8. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1bbd 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d690b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:08:33.564034 [ 22371 ] {f01e021e-1b6f-4403-842b-b921b8ec88e0} TCPHandler: Code: 410. DB::Exception: BridgeHelper: clickhouse-odbc-bridge is not responding. (EXTERNAL_SERVER_IS_NOT_RESPONDING), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/BridgeHelper/IBridgeHelper.cpp:0: DB::IBridgeHelper::startBridgeSync() @ 0x000000001a0d9a59 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::ITableFunctionXDBC::startBridgeIfNot(std::shared_ptr) const @ 0x0000000015ea5d74 6. ./build_docker/./src/TableFunctions/ITableFunctionXDBC.cpp:0: DB::(anonymous namespace)::ITableFunctionXDBC::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015ea567d 7. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 8. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1bbd 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d690b 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:08:33.565125 [ 22371 ] {f01e021e-1b6f-4403-842b-b921b8ec88e0} TCPHandler: Client has gone away. 2025.10.24 00:08:47.684977 [ 18285 ] {5e50f4eb-a303-46fd-b361-786d1439193f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:58584) (comment: 01913_exact_rows_before_limit.sql) (in query: DROP DATABASE IF EXISTS test_h1p2ck5e ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:08:47.686293 [ 18285 ] {5e50f4eb-a303-46fd-b361-786d1439193f} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:08:48.676067 [ 30738 ] {e3294021-0aa4-478e-9036-d2f09da05551} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:58614) (comment: 03122_analyzer_collate_in_window_function.sql) (in query: DROP DATABASE IF EXISTS test_3185vmx0 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:08:48.677363 [ 30738 ] {e3294021-0aa4-478e-9036-d2f09da05551} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:08:49.541796 [ 21666 ] {7ef71d83-79ed-4bf3-955d-ddf7c1bdb0ad} executeQuery: Code: 36. DB::Exception: Element of set in IN, VALUES, or LIMIT, or aggregate function parameter, or a table function argument is not a constant expression (result column not found): globalIn(tuple(_CAST(NULL, 'Nullable(Nothing)'), _CAST(NULL, 'Nullable(Nothing)'), 0), some_identifier). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:34418) (comment: 02002_global_subqueries_subquery_or_table_name.sql) (in query: SELECT cityHash64(number GLOBAL IN (NULL, -2147483648, -9223372036854775808), nan, 1024, NULL, NULL, 1.000100016593933, NULL), (NULL, cityHash64(inf, -2147483648, NULL, NULL, 10.000100135803223), cityHash64(1.1754943508222875e-38, NULL, NULL, NULL), 2147483647) FROM cluster(test_cluster_two_shards_localhost, numbers((NULL, cityHash64(0., 65536, NULL, NULL, 10000000000., NULL), 0) GLOBAL IN (some_identifier), 65536)) WHERE number GLOBAL IN [1025] --{serverError BAD_ARGUMENTS, 284} ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:0: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x00000000181eb876 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181ebdf6 6. ./contrib/llvm-project/libcxx/include/__utility/pair.h:513: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x0000000015e66aaa 7. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:0: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015e6640a 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 9. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 11. ./contrib/llvm-project/libcxx/include/vector:1596: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a5315 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 30. __tsan_thread_start_func @ 0x000000000758df2f 31. ? @ 0x00007f7c69445ac3 2025.10.24 00:08:49.542719 [ 21666 ] {7ef71d83-79ed-4bf3-955d-ddf7c1bdb0ad} TCPHandler: Code: 36. DB::Exception: Element of set in IN, VALUES, or LIMIT, or aggregate function parameter, or a table function argument is not a constant expression (result column not found): globalIn(tuple(_CAST(NULL, 'Nullable(Nothing)'), _CAST(NULL, 'Nullable(Nothing)'), 0), some_identifier). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x0000000007654cc0 4. ./build_docker/./src/Interpreters/evaluateConstantExpression.cpp:0: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x00000000181eb876 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000181ebdf6 6. ./contrib/llvm-project/libcxx/include/__utility/pair.h:513: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x0000000015e66aaa 7. ./build_docker/./src/TableFunctions/TableFunctionNumbers.cpp:0: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000015e6640a 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x0000000016238640 9. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000175b3741 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a7cc0 11. ./contrib/llvm-project/libcxx/include/vector:1596: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000174a5315 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000174d69b9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000174996ef 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 30. __tsan_thread_start_func @ 0x000000000758df2f 31. ? @ 0x00007f7c69445ac3 2025.10.24 00:08:53.151715 [ 30738 ] {64040cbb-525b-4f63-a195-750e9b434e75} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:42340) (comment: 00932_geohash_support.sql) (in query: DROP DATABASE IF EXISTS test_2u3ekybq ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:08:53.153214 [ 30738 ] {64040cbb-525b-4f63-a195-750e9b434e75} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:08:53.165058 [ 21666 ] {d54990fa-ada2-4cea-8a15-42fd7b0f283c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:42342) (comment: 00932_geohash_support.sql) (in query: DROP DATABASE IF EXISTS test_2u3ekybq ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:08:53.166475 [ 21666 ] {d54990fa-ada2-4cea-8a15-42fd7b0f283c} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:08:53.177385 [ 30738 ] {fb17a872-9aeb-4f67-8bb3-35d4f4b92f84} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:42350) (comment: 00932_geohash_support.sql) (in query: DROP DATABASE IF EXISTS test_2u3ekybq ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:08:53.178733 [ 30738 ] {fb17a872-9aeb-4f67-8bb3-35d4f4b92f84} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:08:53.192148 [ 21666 ] {199722a6-1243-4cda-b57c-1b21f9d13972} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:42352) (comment: 00932_geohash_support.sql) (in query: DROP DATABASE IF EXISTS test_2u3ekybq ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:08:53.195593 [ 21666 ] {199722a6-1243-4cda-b57c-1b21f9d13972} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:08:58.021163 [ 3222 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:08:58.567486 [ 21666 ] {a673cae1-7f2f-4c34-9125-725755aedc44} executeQuery: Code: 57. DB::Exception: Table test_xg84r0wl.json_each_row_nested already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:34566) (comment: 00715_json_each_row_input_nested.sh) (in query: CREATE TABLE json_each_row_nested (d1 UInt8, d2 String, n Nested (s String, i Int32) ) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.24 00:08:58.569254 [ 21666 ] {a673cae1-7f2f-4c34-9125-725755aedc44} TCPHandler: Code: 57. DB::Exception: Table test_xg84r0wl.json_each_row_nested already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x0000000007617406 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c56300 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4daaa 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 2025.10.24 00:09:03.874351 [ 11329 ] {} ExternalDictionariesLoader: Could not update external dictionary '4d942a90-5124-4d50-8e84-011027e2fc87', leaving the previous version, next update is scheduled at 2025-10-24 00:09:08: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bfc297 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000019bfd21f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f57e90 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f581e4 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019bf9bd6 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bf97d5 16. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x0000000019abec34 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aba072 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c63e3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 24. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 25. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 28. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a30a201 30. ./build_docker/./src/Dictionaries/DictionaryPipelineExecutor.cpp:0: DB::DictionaryPipelineExecutor::pull(DB::Block&) @ 0x000000000ff54611 31. DB::FlatDictionary::loadData() @ 0x000000000ff59b6b (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:09:03.886451 [ 21666 ] {86e2976c-4f1d-475c-8bf8-44362b825ba5} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:38988) (comment: 00704_drop_truncate_memory_table.sh) (in query: DROP DATABASE IF EXISTS test_4qtgavve ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:09:03.888662 [ 21666 ] {86e2976c-4f1d-475c-8bf8-44362b825ba5} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:09:03.940419 [ 22371 ] {2d3f153f-60c2-4d69-b63d-daa504cc349a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:38990) (comment: 00704_drop_truncate_memory_table.sh) (in query: DROP DATABASE IF EXISTS test_4qtgavve ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:09:03.942022 [ 22371 ] {2d3f153f-60c2-4d69-b63d-daa504cc349a} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:09:04.976541 [ 22371 ] {0c0f3946-94db-4c66-ab78-e803e28dcb00} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT aes_encrypt_mysql(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53050) (comment: 01318_encrypt.sql) (in query: --- aes_encrypt_mysql(string, key, block_mode[, init_vector, AAD]) -- The MySQL-compatitable encryption, only ecb, cbc and ofb modes are supported, -- just like for MySQL -- https://dev.mysql.com/doc/refman/8.0/en/encryption-functions.html#function_aes-encrypt -- https://dev.mysql.com/doc/refman/8.0/en/server-system-variables.html#sysvar_block_encryption_mode -- Please note that for keys that exceed mode-specific length, keys are folded in a MySQL-specific way, -- meaning that whole key is used, but effective key length is still determined by mode. -- when key doesn't exceed the default mode length, ecryption result equals with AES_encypt() ----------------------------------------------------------------------------------------- -- error cases ----------------------------------------------------------------------------------------- SELECT aes_encrypt_mysql();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000007649e6c 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007647bf1 5. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000888b719 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:09:04.978762 [ 22371 ] {0c0f3946-94db-4c66-ab78-e803e28dcb00} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT aes_encrypt_mysql(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000007649e6c 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007647bf1 5. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000888b719 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:09:04.987233 [ 22371 ] {572e5682-8cd3-4d55-af8e-6592fc8c1c72} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT aes_encrypt_mysql('aes-128-ecb'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53050) (comment: 01318_encrypt.sql) (in query: SELECT aes_encrypt_mysql('aes-128-ecb');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000007649e6c 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007647bf1 5. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000888b719 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:09:04.987700 [ 22371 ] {572e5682-8cd3-4d55-af8e-6592fc8c1c72} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 1 argument: In scope SELECT aes_encrypt_mysql('aes-128-ecb'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000007649e6c 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007647bf1 5. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000888b719 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:09:04.994848 [ 22371 ] {0d54107a-bcd8-4fb1-8dea-11af0ee85bda} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53050) (comment: 01318_encrypt.sql) (in query: SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000007649e6c 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007647bf1 5. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000888b719 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:09:04.995335 [ 22371 ] {0d54107a-bcd8-4fb1-8dea-11af0ee85bda} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000007649e6c 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007647bf1 5. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000888b719 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:09:05.503352 [ 22371 ] {61ceb0c1-64b1-44c3-a330-06c91d624157} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'aes_encrypt_mysql'. Expected: encryption mode string, got: UInt16: In scope SELECT aes_encrypt_mysql(789, '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53050) (comment: 01318_encrypt.sql) (in query: SELECT aes_encrypt_mysql(789, '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000888b719 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.24 00:09:05.504270 [ 22371 ] {61ceb0c1-64b1-44c3-a330-06c91d624157} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'aes_encrypt_mysql'. Expected: encryption mode string, got: UInt16: In scope SELECT aes_encrypt_mysql(789, '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000888b719 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.24 00:09:06.265497 [ 22371 ] {aa0b5219-4723-42f6-9264-fd6c68da8134} executeQuery: Code: 36. DB::Exception: Invalid mode: blah blah blah: In scope SELECT aes_encrypt_mysql('blah blah blah', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53050) (comment: 01318_encrypt.sql) (in query: SELECT aes_encrypt_mysql('blah blah blah', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000888b18e 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.24 00:09:06.266753 [ 22371 ] {aa0b5219-4723-42f6-9264-fd6c68da8134} TCPHandler: Code: 36. DB::Exception: Invalid mode: blah blah blah: In scope SELECT aes_encrypt_mysql('blah blah blah', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000888b18e 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.24 00:09:06.283389 [ 22371 ] {ccd852ca-3abc-40c1-8da1-cba4465d2751} executeQuery: Code: 36. DB::Exception: Invalid mode: des-ede3-ecb: In scope SELECT aes_encrypt_mysql('des-ede3-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53050) (comment: 01318_encrypt.sql) (in query: SELECT aes_encrypt_mysql('des-ede3-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000888b18e 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.24 00:09:06.284631 [ 22371 ] {ccd852ca-3abc-40c1-8da1-cba4465d2751} TCPHandler: Code: 36. DB::Exception: Invalid mode: des-ede3-ecb: In scope SELECT aes_encrypt_mysql('des-ede3-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000888b18e 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.24 00:09:07.196527 [ 22371 ] {7f063213-0261-48b5-b611-bc8b5c6f5e60} executeQuery: Code: 36. DB::Exception: Unsupported cipher mode: In scope SELECT aes_encrypt_mysql('aes-128-gcm', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53050) (comment: 01318_encrypt.sql) (in query: SELECT aes_encrypt_mysql('aes-128-gcm', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000888b2a8 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.24 00:09:07.197768 [ 22371 ] {7f063213-0261-48b5-b611-bc8b5c6f5e60} TCPHandler: Code: 36. DB::Exception: Unsupported cipher mode: In scope SELECT aes_encrypt_mysql('aes-128-gcm', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000888b2a8 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.24 00:09:08.072278 [ 22371 ] {00fcad92-6ab8-4299-9e25-8617acb3c921} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'encrypt'. Expected: encryption mode string, got: UInt16: In scope SELECT encrypt(789, '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53050) (comment: 01318_encrypt.sql) (in query: SELECT encrypt(789, '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000999d9d3 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.24 00:09:08.073547 [ 22371 ] {00fcad92-6ab8-4299-9e25-8617acb3c921} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'encrypt'. Expected: encryption mode string, got: UInt16: In scope SELECT encrypt(789, '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000999d9d3 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.24 00:09:09.009337 [ 22371 ] {1ada91f4-2006-45de-9c15-10e5b119b4b6} executeQuery: Code: 36. DB::Exception: Invalid mode: blah blah blah: In scope SELECT encrypt('blah blah blah', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53050) (comment: 01318_encrypt.sql) (in query: SELECT encrypt('blah blah blah', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000999d298 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.24 00:09:09.010400 [ 22371 ] {1ada91f4-2006-45de-9c15-10e5b119b4b6} TCPHandler: Code: 36. DB::Exception: Invalid mode: blah blah blah: In scope SELECT encrypt('blah blah blah', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000999d298 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.24 00:09:09.059613 [ 22371 ] {176b5624-f113-4848-ac83-5e45debaad57} executeQuery: Code: 36. DB::Exception: Invalid mode: des-ede3-ecb: In scope SELECT encrypt('des-ede3-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53050) (comment: 01318_encrypt.sql) (in query: SELECT encrypt('des-ede3-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000999d298 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.24 00:09:09.061195 [ 22371 ] {176b5624-f113-4848-ac83-5e45debaad57} TCPHandler: Code: 36. DB::Exception: Invalid mode: des-ede3-ecb: In scope SELECT encrypt('des-ede3-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000999d298 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.24 00:09:09.076105 [ 22371 ] {8891fda6-a42d-4990-8c26-053b3272443c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'key' to function 'aes_encrypt_mysql'. Expected: encryption key binary string, got: UInt16: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53050) (comment: 01318_encrypt.sql) (in query: SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000888b719 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.24 00:09:09.077484 [ 22371 ] {8891fda6-a42d-4990-8c26-053b3272443c} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'key' to function 'aes_encrypt_mysql'. Expected: encryption key binary string, got: UInt16: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000888b719 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.24 00:09:09.711710 [ 22371 ] {38e4163c-acaa-4856-b8d3-6bcb4f1c7bf8} executeQuery: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53050) (comment: 01318_encrypt.sql) (in query: SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000008889946 4. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000888bf7f 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000888ae17 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 2025.10.24 00:09:09.712903 [ 22371 ] {38e4163c-acaa-4856-b8d3-6bcb4f1c7bf8} TCPHandler: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000008889946 4. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000888bf7f 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000888ae17 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 2025.10.24 00:09:09.983225 [ 22371 ] {5ff4aa3d-29ae-4353-b70a-00e6953c45c7} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'encrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 2 arguments: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53050) (comment: 01318_encrypt.sql) (in query: SELECT encrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000007649e6c 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007647bf1 5. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000999d9d3 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:09:09.983905 [ 22371 ] {5ff4aa3d-29ae-4353-b70a-00e6953c45c7} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'encrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 2 arguments: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000007649e6c 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007647bf1 5. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000999d9d3 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:09:09.991240 [ 22371 ] {acb602ee-0654-455a-bd4b-ea28b194074f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'key' to function 'encrypt'. Expected: encryption key binary string, got: UInt16: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53050) (comment: 01318_encrypt.sql) (in query: SELECT encrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000999d9d3 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.24 00:09:09.991742 [ 22371 ] {acb602ee-0654-455a-bd4b-ea28b194074f} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'key' to function 'encrypt'. Expected: encryption key binary string, got: UInt16: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764781e 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000999d9d3 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.24 00:09:11.049496 [ 22371 ] {c27b701c-332d-40f8-a747-df3db5984631} executeQuery: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53050) (comment: 01318_encrypt.sql) (in query: SELECT encrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000008889946 4. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000999e8a7 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000999cee6 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 2025.10.24 00:09:11.051251 [ 22371 ] {c27b701c-332d-40f8-a747-df3db5984631} TCPHandler: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000008889946 4. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000999e8a7 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000999cee6 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 2025.10.24 00:09:11.065402 [ 22371 ] {aa898578-75c6-4715-b7f0-cd095084a55f} executeQuery: Code: 36. DB::Exception: Invalid key size: 36 expected 16: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53050) (comment: 01318_encrypt.sql) (in query: SELECT encrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000008889946 4. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000999e8a7 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000999cee6 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 2025.10.24 00:09:11.066704 [ 22371 ] {aa898578-75c6-4715-b7f0-cd095084a55f} TCPHandler: Code: 36. DB::Exception: Invalid key size: 36 expected 16: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000008889946 4. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000999e8a7 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000999cee6 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 2025.10.24 00:09:11.635005 [ 22371 ] {ac5e5e13-cb3c-433f-a4d2-fc9433f99763} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'IV' to function 'aes_encrypt_mysql'. Expected: Initialization vector binary string, got: UInt16: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53050) (comment: 01318_encrypt.sql) (in query: SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764787a 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000888b719 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.24 00:09:11.635794 [ 22371 ] {ac5e5e13-cb3c-433f-a4d2-fc9433f99763} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'IV' to function 'aes_encrypt_mysql'. Expected: Initialization vector binary string, got: UInt16: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764787a 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000888b719 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.24 00:09:12.489582 [ 22371 ] {7fce6366-fc74-4375-a241-a6c653be6e10} executeQuery: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53050) (comment: 01318_encrypt.sql) (in query: SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000008889946 4. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000888bf7f 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000888aeb1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 2025.10.24 00:09:12.491026 [ 22371 ] {7fce6366-fc74-4375-a241-a6c653be6e10} TCPHandler: Code: 36. DB::Exception: Invalid key size: 3 expected 16: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x0000000008889946 4. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000888bf7f 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000888aeb1 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 2025.10.24 00:09:13.192872 [ 22371 ] {2d21a3fe-7f8c-4548-8aa7-fb4c868cc893} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'IV' to function 'encrypt'. Expected: Initialization vector binary string, got: UInt16: In scope SELECT encrypt('aes-128-cbc', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53050) (comment: 01318_encrypt.sql) (in query: SELECT encrypt('aes-128-cbc', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764787a 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000999d9d3 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.24 00:09:13.194244 [ 22371 ] {2d21a3fe-7f8c-4548-8aa7-fb4c868cc893} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3th argument 'IV' to function 'encrypt'. Expected: Initialization vector binary string, got: UInt16: In scope SELECT encrypt('aes-128-cbc', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764787a 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000999d9d3 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.24 00:09:14.017004 [ 22371 ] {eda01395-932d-4e8c-8b4c-fd349c66fb62} executeQuery: Code: 36. DB::Exception: Invalid IV size: 42 expected 16: In scope SELECT encrypt('aes-128-cbc', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53050) (comment: 01318_encrypt.sql) (in query: SELECT encrypt('aes-128-cbc', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000008889ea6 4. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000999eb5e 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000999cfaa 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 2025.10.24 00:09:14.017705 [ 22371 ] {eda01395-932d-4e8c-8b4c-fd349c66fb62} TCPHandler: Code: 36. DB::Exception: Invalid IV size: 42 expected 16: In scope SELECT encrypt('aes-128-cbc', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000008889ea6 4. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000999eb5e 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000999cfaa 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 2025.10.24 00:09:14.026892 [ 22371 ] {902ed9e3-e946-492b-b365-8bbd43040051} executeQuery: Code: 36. DB::Exception: Invalid IV size: 2 expected 16: In scope SELECT encrypt('aes-128-cbc', '[HIDDEN]'). (BAD_ARGUMENTS) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53050) (comment: 01318_encrypt.sql) (in query: SELECT encrypt('aes-128-cbc', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000008889ea6 4. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000999eb5e 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000999cfaa 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 2025.10.24 00:09:14.028125 [ 22371 ] {902ed9e3-e946-492b-b365-8bbd43040051} TCPHandler: Code: 36. DB::Exception: Invalid IV size: 2 expected 16: In scope SELECT encrypt('aes-128-cbc', '[HIDDEN]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x0000000008889ea6 4. DB::FunctionEncrypt::doEncrypt(evp_cipher_st const*, unsigned long, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&) @ 0x000000000999eb5e 5. DB::FunctionEncrypt::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000999cfaa 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007614264 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007636a5c 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087145e7 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087140be 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008714574 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087151d5 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c309f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 2025.10.24 00:09:14.039028 [ 22371 ] {44e6551e-5d64-4b4c-8070-859605fed3af} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 5 arguments: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53050) (comment: 01318_encrypt.sql) (in query: SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000007649e6c 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007647bf1 5. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000888b719 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:09:14.039828 [ 22371 ] {44e6551e-5d64-4b4c-8070-859605fed3af} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 5 arguments: In scope SELECT aes_encrypt_mysql('aes-128-ecb', '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000007649e6c 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000007647bf1 5. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000888b719 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 31. __tsan_thread_start_func @ 0x000000000758df2f 2025.10.24 00:09:14.053136 [ 22371 ] {f973f0cb-6315-4928-9710-b60930ebd4a9} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'AAD' to function 'encrypt'. Expected: Additional authenticated data binary string for GCM mode, got: UInt16: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53050) (comment: 01318_encrypt.sql) (in query: SELECT encrypt('aes-128-ecb', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764787a 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000999d9d3 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.24 00:09:14.054016 [ 22371 ] {f973f0cb-6315-4928-9710-b60930ebd4a9} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'AAD' to function 'encrypt'. Expected: Additional authenticated data binary string for GCM mode, got: UInt16: In scope SELECT encrypt('aes-128-ecb', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764787a 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000999d9d3 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.24 00:09:14.066567 [ 22371 ] {2eaf1275-0d71-4b62-bcc1-fd7aa40da196} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'AAD' to function 'encrypt'. Expected: Additional authenticated data binary string for GCM mode, got: UInt16: In scope SELECT encrypt('aes-128-gcm', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53050) (comment: 01318_encrypt.sql) (in query: SELECT encrypt('aes-128-gcm', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764787a 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000999d9d3 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.24 00:09:14.067858 [ 22371 ] {2eaf1275-0d71-4b62-bcc1-fd7aa40da196} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 4th argument 'AAD' to function 'encrypt'. Expected: Additional authenticated data binary string for GCM mode, got: UInt16: In scope SELECT encrypt('aes-128-gcm', '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000764ab3c 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000007647ff4 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000764787a 6. DB::FunctionEncrypt::getReturnTypeImpl(std::vector> const&) const @ 0x000000000999d9d3 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000076351fa 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000008717e8b 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000008717b77 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000871864b 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3426: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174c2dd4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000174a1d66 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3910: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x00000000174a0abb 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000174d3d45 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000017499774 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000017498627 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000017497a85 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x0000000017c91047 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000017dc2870 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000017dbf560 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: std::unique_ptr> std::__function::__policy_invoker> (DB::InterpreterFactory::Arguments const&)>::__call_impl> (DB::InterpreterFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::InterpreterFactory::Arguments const&) @ 0x0000000017dc3bb0 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x0000000017d42e2e 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220027 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 2025.10.24 00:09:14.416641 [ 3318 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4a6404b7-e320-48a8-83da-1f6d279d54c0::202510_1_165_64}: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fa36f06 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000000fa34b23 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000000f9c38f7 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000000fa6ada2 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x0000000019ea2870 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b2a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:09:15.523598 [ 18285 ] {291d0bcd-9278-4345-b484-019cb1de873f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=746). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:33484) (comment: 01213_alter_rename_column_zookeeper_long.sh) (in query: SELECT name FROM system.columns WHERE name = 'renamed_value1' and table = 'table_for_rename_replicated' AND database = 'test_13'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:09:15.524856 [ 18285 ] {291d0bcd-9278-4345-b484-019cb1de873f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=746). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:09:17.335994 [ 22371 ] {01539d21-62e8-4846-9c91-528e9a1f850c} executeQuery: Code: 60. DB::Exception: Table `02961_db1`.`02961_tb1` does not exist. Maybe you meant `02961_db2`.`02961_tb3`?. (UNKNOWN_TABLE) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:33486) (comment: 02961_drop_tables.sql) (in query: DROP TABLE 02961_db2.02961_tb4, 02961_db1.02961_tb1, 02961_db2.02961_tb5;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000771afd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171414d5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000017697dc1 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:971: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001769f384 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c7515b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c74615 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c739c9 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.24 00:09:17.336637 [ 22371 ] {01539d21-62e8-4846-9c91-528e9a1f850c} TCPHandler: Code: 60. DB::Exception: Table `02961_db1`.`02961_tb1` does not exist. Maybe you meant `02961_db2`.`02961_tb3`?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000771afd4 4. ./build_docker/./src/Databases/IDatabase.cpp:0: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x00000000171414d5 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x0000000017697dc1 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:971: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x000000001769f384 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c7515b 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c74615 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c739c9 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.24 00:09:17.635189 [ 22371 ] {bb24ddfb-24f2-4881-88b1-3b32cd81011e} executeQuery: Code: 705. DB::Exception: Table tab2 is not empty. (TABLE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:33486) (comment: 02961_drop_tables.sql) (in query: DROP TABLE IF EMPTY tab1, tab2, tab3;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c76fe9 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c74615 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c739c9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:09:17.636092 [ 22371 ] {bb24ddfb-24f2-4881-88b1-3b32cd81011e} TCPHandler: Code: 705. DB::Exception: Table tab2 is not empty. (TABLE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c76fe9 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c74615 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c739c9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:09:18.038360 [ 22371 ] {c71ece66-2d40-410e-b204-59525162b305} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:33486) (comment: 02961_drop_tables.sql) (in query: DROP DATABASE IF EXISTS 02961_db2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:09:18.041654 [ 22371 ] {c71ece66-2d40-410e-b204-59525162b305} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:09:18.113824 [ 21666 ] {abe96fd4-7bfa-4ee3-b55b-f8fe4719e3e6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56026) (comment: 02961_drop_tables.sql) (in query: DROP DATABASE IF EXISTS test_wad9zebm ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:09:18.116392 [ 21666 ] {abe96fd4-7bfa-4ee3-b55b-f8fe4719e3e6} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:09:18.134047 [ 22371 ] {31a2724e-2fd1-4577-96f9-bac43e978a03} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:56042) (comment: 02961_drop_tables.sql) (in query: DROP DATABASE IF EXISTS test_wad9zebm ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:09:18.136221 [ 22371 ] {31a2724e-2fd1-4577-96f9-bac43e978a03} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:09:18.795213 [ 10932 ] {99c10956-35fd-4bc2-b1e6-c2459f193c9d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:33532) (comment: 02961_drop_tables.sql) (in query: DROP DATABASE IF EXISTS 02961_db2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:09:18.795902 [ 10932 ] {99c10956-35fd-4bc2-b1e6-c2459f193c9d} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:09:19.504433 [ 18285 ] {fd6b308a-3151-4e4b-9ef4-044c23c08f30} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57838) (comment: 02961_drop_tables.sql) (in query: DROP DATABASE IF EXISTS 02961_db2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:09:19.505650 [ 18285 ] {fd6b308a-3151-4e4b-9ef4-044c23c08f30} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:09:20.109478 [ 18285 ] {aab49c01-142e-4e52-8d56-3bfe4483f3b7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57844) (comment: 02961_drop_tables.sql) (in query: DROP DATABASE IF EXISTS 02961_db2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:09:20.110604 [ 18285 ] {aab49c01-142e-4e52-8d56-3bfe4483f3b7} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:09:20.836113 [ 10932 ] {1b470fee-a170-477e-967a-59b9996a59c0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=746). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57858) (comment: 03019_numbers_pretty.sql) (in query: SELECT inf FORMAT Pretty;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:09:20.837817 [ 10932 ] {1b470fee-a170-477e-967a-59b9996a59c0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=746). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:09:21.611155 [ 3308 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a53b52a7-30bb-4113-8a6d-7dc62d6781f8::202510_1_156_31}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:09:21.696932 [ 18285 ] {283d18ce-ea50-45d5-9f0d-5295bf616640} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57872) (comment: 01517_drop_mv_with_inner_table.sql) (in query: -- ensure that the inner had been removed after sync drop drop table db_01517_atomic.source sync;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1e9f1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c766aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c74615 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c739c9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:09:21.697807 [ 18285 ] {283d18ce-ea50-45d5-9f0d-5295bf616640} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./src/Storages/IStorage.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015f1e9f1 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000017c766aa 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x0000000017c74615 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c739c9 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:09:23.572616 [ 18285 ] {885618d9-a04c-4867-b570-f1975e30d68c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:57898) (comment: 00955_test_final_mark.sql) (in query: OPTIMIZE TABLE mt_with_pk FINAL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x0000000019e62f76 22. ./build_docker/./src/Storages/StorageMergeTree.cpp:1609: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000019e69ccb 23. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000018286d18 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.24 00:09:23.573388 [ 18285 ] {885618d9-a04c-4867-b570-f1975e30d68c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x0000000019e62f76 22. ./build_docker/./src/Storages/StorageMergeTree.cpp:1609: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000019e69ccb 23. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000018286d18 24. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 2025.10.24 00:09:27.903519 [ 10932 ] {0bd8022c-f29e-45ed-b3c2-501ce13a68ea} executeQuery: Code: 117. DB::Exception: Unknown field found in format header: 'y' at position 1 Set the 'input_format_skip_unknown_fields' parameter explicitly to ignore and proceed: (while reading header): (in file/uri /var/lib/clickhouse/user_files/dump1.sql): While executing MySQLDumpRowInputFormat: While executing File. (INCORRECT_DATA) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:58010) (comment: 02286_mysql_dump_input_format.sh) (in query: select * from file(dump1.sql, MySQLDump, 'x Nullable(Int32), z String') order by x, z settings input_format_skip_unknown_fields = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x0000000008707a26 4. ./build_docker/./src/Formats/ColumnMapping.cpp:38: DB::ColumnMapping::addColumns(std::vector> const&, google::dense_hash_map, google::libc_allocator_with_realloc>> const&, DB::FormatSettings const&) @ 0x000000001a3d3168 5. ./build_docker/./src/Processors/Formats/Impl/MySQLDumpRowInputFormat.cpp:360: DB::MySQLDumpRowInputFormat::readPrefix() @ 0x000000001a4cf72b 6. ./src/Processors/ISource.h:41: DB::IRowInputFormat::read() @ 0x000000001a39e89b 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001a311955 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2e13d5 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x00000000191d61a4 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2e13d5 16. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 17. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.24 00:09:27.905309 [ 10932 ] {0bd8022c-f29e-45ed-b3c2-501ce13a68ea} TCPHandler: Code: 117. DB::Exception: Unknown field found in format header: 'y' at position 1 Set the 'input_format_skip_unknown_fields' parameter explicitly to ignore and proceed: (while reading header): (in file/uri /var/lib/clickhouse/user_files/dump1.sql): While executing MySQLDumpRowInputFormat: While executing File. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, unsigned long&&) @ 0x0000000008707a26 4. ./build_docker/./src/Formats/ColumnMapping.cpp:38: DB::ColumnMapping::addColumns(std::vector> const&, google::dense_hash_map, google::libc_allocator_with_realloc>> const&, DB::FormatSettings const&) @ 0x000000001a3d3168 5. ./build_docker/./src/Processors/Formats/Impl/MySQLDumpRowInputFormat.cpp:360: DB::MySQLDumpRowInputFormat::readPrefix() @ 0x000000001a4cf72b 6. ./src/Processors/ISource.h:41: DB::IRowInputFormat::read() @ 0x000000001a39e89b 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001a311955 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2e13d5 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x00000000191d61a4 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2e13d5 16. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 17. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.24 00:09:33.159171 [ 18285 ] {78d2e614-f02c-48ea-a538-76c55c1af088} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a MySQLDump format file. Error: Code: 92. DB::Exception: There is no INSERT queries for table test 3 in MySQL dump file. (EMPTY_DATA_PASSED) (version 24.8.14.10544.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/dump1.sql). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36058) (comment: 02286_mysql_dump_input_format.sh) (in query: desc file(dump1.sql, MySQLDump) settings input_format_mysql_dump_table_name='test 3'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000e123b06 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:481: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001a2a17be 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001a2a2d34 6. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000191ccd29 7. ./src/Storages/ColumnsDescription.h:113: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000191cd5c0 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000015e81def 9. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000001829121c 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:92: DB::InterpreterDescribeQuery::execute() @ 0x000000001828ffbe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.24 00:09:33.160578 [ 18285 ] {78d2e614-f02c-48ea-a538-76c55c1af088} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a MySQLDump format file. Error: Code: 92. DB::Exception: There is no INSERT queries for table test 3 in MySQL dump file. (EMPTY_DATA_PASSED) (version 24.8.14.10544.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/dump1.sql). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000e123b06 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:481: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001a2a17be 5. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001a2a2d34 6. ./build_docker/./src/Storages/StorageFile.cpp:0: DB::StorageFile::getTableStructureAndFormatFromFileImpl(std::optional, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000191ccd29 7. ./src/Storages/ColumnsDescription.h:113: DB::StorageFile::getTableStructureFromFile(String const&, std::vector> const&, String const&, std::optional const&, std::shared_ptr const&, std::optional const&) @ 0x00000000191cd5c0 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::TableFunctionFile::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000015e81def 9. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x000000001829121c 10. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:92: DB::InterpreterDescribeQuery::execute() @ 0x000000001828ffbe 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x000000001821c338 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000001a1ebf1c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.24 00:09:33.909025 [ 10932 ] {b3f4d7ca-7945-4552-a6ba-0a94e97baebe} executeQuery: Code: 92. DB::Exception: There is no INSERT queries for table test 3 in MySQL dump file: (while reading header): (in file/uri /var/lib/clickhouse/user_files/dump1.sql): While executing MySQLDumpRowInputFormat: While executing File. (EMPTY_DATA_PASSED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36076) (comment: 02286_mysql_dump_input_format.sh) (in query: select * from file(dump1.sql, MySQLDump, 'x Nullable(Int32)') settings input_format_mysql_dump_table_name='test 3'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Processors/Formats/Impl/MySQLDumpRowInputFormat.cpp:347: DB::readFirstCreateAndInsertQueries(DB::ReadBuffer&, String&, DB::NamesAndTypesList&, std::vector>&) @ 0x000000001a4cffdf 5. ./build_docker/./src/Processors/Formats/Impl/MySQLDumpRowInputFormat.cpp:0: DB::MySQLDumpRowInputFormat::readPrefix() @ 0x000000001a4cf6d1 6. ./src/Processors/ISource.h:41: DB::IRowInputFormat::read() @ 0x000000001a39e89b 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001a311955 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2e13d5 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x00000000191d61a4 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2e13d5 16. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 17. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.24 00:09:33.911023 [ 10932 ] {b3f4d7ca-7945-4552-a6ba-0a94e97baebe} TCPHandler: Code: 92. DB::Exception: There is no INSERT queries for table test 3 in MySQL dump file: (while reading header): (in file/uri /var/lib/clickhouse/user_files/dump1.sql): While executing MySQLDumpRowInputFormat: While executing File. (EMPTY_DATA_PASSED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x0000000007614d00 4. ./build_docker/./src/Processors/Formats/Impl/MySQLDumpRowInputFormat.cpp:347: DB::readFirstCreateAndInsertQueries(DB::ReadBuffer&, String&, DB::NamesAndTypesList&, std::vector>&) @ 0x000000001a4cffdf 5. ./build_docker/./src/Processors/Formats/Impl/MySQLDumpRowInputFormat.cpp:0: DB::MySQLDumpRowInputFormat::readPrefix() @ 0x000000001a4cf6d1 6. ./src/Processors/ISource.h:41: DB::IRowInputFormat::read() @ 0x000000001a39e89b 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000001a311955 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2e13d5 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe 14. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x00000000191d61a4 15. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000001a2e13d5 16. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 17. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 25. __tsan_thread_start_func @ 0x000000000758df2f 26. ? @ 0x00007f7c69445ac3 27. ? @ 0x00007f7c694d7850 2025.10.24 00:09:43.762562 [ 3497 ] {} ExternalDictionariesLoader: Could not update external dictionary '4d942a90-5124-4d50-8e84-011027e2fc87', leaving the previous version, next update is scheduled at 2025-10-24 00:09:49: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=0): (while reading column key_column): (while reading from part /var/lib/clickhouse/store/847/8471dccc-d02b-4a9b-be32-a2c153b48d95/all_1_1_0/ in table database_for_dict.table_for_dict (8471dccc-d02b-4a9b-be32-a2c153b48d95) located on disk default of type local, from mark 0 with max_rows_to_read = 100): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000016d64235 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d65c54 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d661ce 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016fe4dcb 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f58c32 18. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:0: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000001702b604 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x0000000019bfbc4a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bfb20e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a98c8ea 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 28. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 29. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:09:49.112408 [ 3024 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:09:53.470415 [ 5096 ] {} ExternalDictionariesLoader: Could not update external dictionary '4d942a90-5124-4d50-8e84-011027e2fc87', leaving the previous version, next update is scheduled at 2025-10-24 00:09:59: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=0): (while reading column fourth_column): (while reading from part /var/lib/clickhouse/store/847/8471dccc-d02b-4a9b-be32-a2c153b48d95/all_1_1_0/ in table database_for_dict.table_for_dict (8471dccc-d02b-4a9b-be32-a2c153b48d95) located on disk default of type local, from mark 0 with max_rows_to_read = 100): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:217: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x0000000016d64235 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d65c54 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000016d661ce 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000016ff348b 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f58c32 18. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:0: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x000000001702b604 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x0000000019bfbc4a 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bfb20e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a98c8ea 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 28. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 29. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:09:54.017270 [ 2856 ] {} RefreshTask: Refresh view test_13.e failed (attempt 1/1): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 15. ./src/Interpreters/InterpreterCreateQuery.h:29: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x0000000017c5085a 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1535: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4da81 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 18. ./build_docker/./src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x00000000192bab92 19. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:380: DB::RefreshTask::executeRefreshUnlocked(bool) @ 0x0000000019ff6028 20. ./contrib/llvm-project/libcxx/include/__mutex_base:207: DB::RefreshTask::refreshTask() @ 0x0000000019ff46e8 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019ff7522 22. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 24. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:10:19.100887 [ 2848 ] {} RefreshTask: Refresh view test_13.e failed (attempt 1/1): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 15. ./src/Interpreters/InterpreterCreateQuery.h:29: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x0000000017c5085a 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1535: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4da81 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 18. ./build_docker/./src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x00000000192bab92 19. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:380: DB::RefreshTask::executeRefreshUnlocked(bool) @ 0x0000000019ff6028 20. ./contrib/llvm-project/libcxx/include/__mutex_base:207: DB::RefreshTask::refreshTask() @ 0x0000000019ff46e8 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019ff7522 22. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 24. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:10:19.756044 [ 18285 ] {4626eda8-ce33-4b35-9ebd-b6ce99cc1f0c} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while executing 'FUNCTION CAST(arrayJoin(_CAST([NULL, '', '', NULL, '', NULL, '01.02.2017 03:04\005GMT', '', NULL, '01/02/2017 03:04:05 MSK01/02/\0017 03:04:05 MSK', '', NULL, '03/04/201903/04/201903/04/\001903/04/2019']_Array(Nullable(String)), 'Array(Nullable(String))'_String)) :: 3, 'Enum8(\'a\' = 1, \'b\' = 2)'_String :: 2) -> CAST(arrayJoin(_CAST([NULL, '', '', NULL, '', NULL, '01.02.2017 03:04\005GMT', '', NULL, '01/02/2017 03:04:05 MSK01/02/\0017 03:04:05 MSK', '', NULL, '03/04/201903/04/201903/04/\001903/04/2019']_Array(Nullable(String)), 'Array(Nullable(String))'_String)), 'Enum8(\'a\' = 1, \'b\' = 2)'_String) Enum8('a' = 1, 'b' = 2) : 1'. (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:36896) (comment: 01536_fuzz_cast.sql) (in query: SELECT CAST(arrayJoin([NULL, '', '', NULL, '', NULL, '01.02.2017 03:04\005GMT', '', NULL, '01/02/2017 03:04:05 MSK01/02/\0017 03:04:05 MSK', '', NULL, '03/04/201903/04/201903/04/\001903/04/2019']), 'Enum8(\'a\' = 1, \'b\' = 2)') AS x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000007a2ee72 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007765447 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087152b7 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.24 00:10:19.757106 [ 18285 ] {4626eda8-ce33-4b35-9ebd-b6ce99cc1f0c} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while executing 'FUNCTION CAST(arrayJoin(_CAST([NULL, '', '', NULL, '', NULL, '01.02.2017 03:04\005GMT', '', NULL, '01/02/2017 03:04:05 MSK01/02/\0017 03:04:05 MSK', '', NULL, '03/04/201903/04/201903/04/\001903/04/2019']_Array(Nullable(String)), 'Array(Nullable(String))'_String)) :: 3, 'Enum8(\'a\' = 1, \'b\' = 2)'_String :: 2) -> CAST(arrayJoin(_CAST([NULL, '', '', NULL, '', NULL, '01.02.2017 03:04\005GMT', '', NULL, '01/02/2017 03:04:05 MSK01/02/\0017 03:04:05 MSK', '', NULL, '03/04/201903/04/201903/04/\001903/04/2019']_Array(Nullable(String)), 'Array(Nullable(String))'_String)), 'Enum8(\'a\' = 1, \'b\' = 2)'_String) Enum8('a' = 1, 'b' = 2) : 1'. (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000007a2ee72 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000007765447 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000871460b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000087152b7 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000008716eef 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000176c844a 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000001a6a73b1 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000000fe45a77 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000001a2ddfa5 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f49ac 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 20. __tsan_thread_start_func @ 0x000000000758df2f 21. ? @ 0x00007f7c69445ac3 22. ? @ 0x00007f7c694d7850 2025.10.24 00:10:24.809823 [ 21666 ] {eeb2a1ed-4136-46e4-92a0-da230d77ee31} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:40440) (comment: 02025_dictionary_array_nested_map.sql) (in query: DROP DATABASE IF EXISTS test_5i0pkqqn ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 2025.10.24 00:10:24.811369 [ 21666 ] {eeb2a1ed-4136-46e4-92a0-da230d77ee31} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000076363fa 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000001769b702 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:474: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000017c79757 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000017c748b8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:95: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000017c73abc 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000017c73710 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 19. __tsan_thread_start_func @ 0x000000000758df2f 20. ? @ 0x00007f7c69445ac3 21. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:10:28.550879 [ 8857 ] {} ExternalDictionariesLoader: Could not update external dictionary '4d942a90-5124-4d50-8e84-011027e2fc87', leaving the previous version, next update is scheduled at 2025-10-24 00:10:33: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=0): (while reading column third_column): (while reading from part /var/lib/clickhouse/store/847/8471dccc-d02b-4a9b-be32-a2c153b48d95/all_1_1_0/ in table database_for_dict.table_for_dict (8471dccc-d02b-4a9b-be32-a2c153b48d95) located on disk default of type local, from mark 0 with max_rows_to_read = 100): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625c5c6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000001625c185 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001625a97e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x000000001624dccf 11. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000001624e37a 12. DB::ReadBuffer::next() @ 0x0000000007b3717b 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000016d62f83 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d65385 15. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000016d655fe 16. DB::ReadBuffer::next() @ 0x0000000007b3717b 17. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000001702f769 18. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x000000001702df6f 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:211: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000016f58c32 20. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x0000000019bfbc4a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bfb20e 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000019bdb290 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000019be8789 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000019be5c28 25. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000019c15b4b 26. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000001a98c8ea 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c106f2 28. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 29. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 30. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:10:51.023861 [ 3183 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:10:51.026414 [ 3128 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:11:12.024511 [ 3164 ] {} RefreshTask: Refresh view test_13.e failed (attempt 1/1): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000199c4725 9. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x0000000019e50604 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, void>(std::allocator const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, DB::LoadingStrictnessLevel const&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&) @ 0x0000000019e4f922 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000019e4a343 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000164738a4 13. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000191c5ba6 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000017c53ef9 15. ./src/Interpreters/InterpreterCreateQuery.h:29: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x0000000017c5085a 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1535: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x0000000017c4da81 17. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a58e 18. ./build_docker/./src/Storages/StorageMaterializedView.cpp:0: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x00000000192bab92 19. ./build_docker/./src/Storages/MaterializedView/RefreshTask.cpp:380: DB::RefreshTask::executeRefreshUnlocked(bool) @ 0x0000000019ff6028 20. ./contrib/llvm-project/libcxx/include/__mutex_base:207: DB::RefreshTask::refreshTask() @ 0x0000000019ff46e8 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000019ff7522 22. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 24. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 27. __tsan_thread_start_func @ 0x000000000758df2f 28. ? @ 0x00007f7c69445ac3 29. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:11:15.496852 [ 3321 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a53b52a7-30bb-4113-8a6d-7dc62d6781f8::202510_1_171_34}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:11:15.520822 [ 3315 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a53b52a7-30bb-4113-8a6d-7dc62d6781f8::202510_1_171_34}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:11:15.538251 [ 3309 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a53b52a7-30bb-4113-8a6d-7dc62d6781f8::202510_1_171_34}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:11:40.979788 [ 3319 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6e0ce121-7b71-4e14-a14f-c7c363eaab4f::202510_377_397_4}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:11:46.004575 [ 3319 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {34e0b00e-fe5a-47d8-af0c-3ae1d30a34d1::202510_231_236_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:11:46.209451 [ 3316 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {34e0b00e-fe5a-47d8-af0c-3ae1d30a34d1::202510_231_236_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:11:46.550006 [ 3309 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {34e0b00e-fe5a-47d8-af0c-3ae1d30a34d1::202510_231_236_1}: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fa36f06 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000000fa34b23 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000000f9c38f7 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x000000000fa6ada2 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x0000000019ea2870 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b2a 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:11:48.730752 [ 11306 ] {} ExternalDictionariesLoader: Could not update external dictionary '4d942a90-5124-4d50-8e84-011027e2fc87', leaving the previous version, next update is scheduled at 2025-10-24 00:11:54: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000019bfc297 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x0000000019bfd21f 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::ISerialization::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000016f57e90 13. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:0: DB::SerializationSparse::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x00000000170291cf 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000016f581e4 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000019bf9bd6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:54: DB::MergeTreeReaderWide::MergeTreeReaderWide(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bf97d5 17. ./contrib/llvm-project/libcxx/include/__tree:1088: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) @ 0x0000000019abec34 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aba072 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000019c13ee3 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000001a987521 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000001a9c63e3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000001a98bb10 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:189: DB::MergeTreeSelectProcessor::read() @ 0x0000000019c1064d 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000001a96c737 25. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000001a2e10ab 26. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000001a303e4a 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f53c3 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000001a2f4d86 29. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000001a309ffe 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000001a30a201 31. ./build_docker/./src/Dictionaries/DictionaryPipelineExecutor.cpp:0: DB::DictionaryPipelineExecutor::pull(DB::Block&) @ 0x000000000ff54611 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:12:16.233410 [ 21666 ] {a456945d-a2bf-4a03-90bb-1815ae6cdcb3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=746). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:39802) (comment: 01213_alter_rename_column_zookeeper_long.sh) (in query: SELECT name FROM system.columns WHERE name = 'renamed_value1' and table = 'table_for_rename_replicated' AND database = 'test_13'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:12:16.235250 [ 21666 ] {a456945d-a2bf-4a03-90bb-1815ae6cdcb3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=783, jobs=746). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb21af8 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1a00e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1abf7 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a307547 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000001a307b27 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000001a1f91fc 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000001a1ec0bf 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000001a20b788 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 17. __tsan_thread_start_func @ 0x000000000758df2f 18. ? @ 0x00007f7c69445ac3 19. ? @ 0x00007f7c694d7850 2025.10.24 00:12:27.835245 [ 3317 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {31dc9f48-44c4-4df8-94b6-f5019085f4b9::202510_1_148_37}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:13:45.460413 [ 3322 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6e0ce121-7b71-4e14-a14f-c7c363eaab4f::202510_377_427_10}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:13:45.663712 [ 3311 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6e0ce121-7b71-4e14-a14f-c7c363eaab4f::202510_377_427_10}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=22, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007f7c69445ac3 31. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:14:08.083222 [ 3185 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:14:10.017882 [ 3209 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:14:11.039868 [ 3154 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007f7c69445ac3 18. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:15:26.458644 [ 35157 ] {2f591c00-b6e6-406b-a224-768da1246b17} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.057923897 seconds, maximum: 60. (TIMEOUT_EXCEEDED) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:54410) (in query: SELECT sleepEachRow(( SELECT maxOrDefault(300 - elapsed) + 1 FROM system.processes WHERE query NOT LIKE '%FROM system.processes%' AND elapsed < 300 ) / 300) FROM numbers(300) FORMAT Null SETTINGS function_sleep_max_microseconds_per_block = 0 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016e05586 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016e046a6 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x0000000017ee8b41 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2f4ac8 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f4708 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 11. __tsan_thread_start_func @ 0x000000000758df2f 12. ? @ 0x00007f7c69445ac3 13. ? @ 0x00007f7c694d7850 2025.10.24 00:15:26.459585 [ 35157 ] {2f591c00-b6e6-406b-a224-768da1246b17} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.057923897 seconds, maximum: 60. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x0000000016e05586 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000016e046a6 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x0000000017ee8b41 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:198: DB::PipelineExecutor::finalizeExecution() @ 0x000000001a2f4ac8 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f4708 8. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 11. __tsan_thread_start_func @ 0x000000000758df2f 12. ? @ 0x00007f7c69445ac3 13. ? @ 0x00007f7c694d7850 2025.10.24 00:15:27.700220 [ 18285 ] {6deb3fa3-a6cc-4ebd-83c7-3cc7440eb9a2} executeQuery: Code: 521. DB::ErrnoException: Cannot rename /var/lib/clickhouse/metadata/test.sql.tmp to /var/lib/clickhouse/metadata/test.sql because the second path already exists: , errno: 17, strerror: File exists. (ATOMIC_RENAME_FAIL) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:53776) (in query: CREATE DATABASE IF NOT EXISTS test ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000170c4008 4. ./build_docker/./src/Common/atomicRename.cpp:92: DB::renameat2(String const&, String const&, int) @ 0x00000000170c3d44 5. ./build_docker/./src/Common/atomicRename.cpp:213: DB::renameNoReplace(String const&, String const&) @ 0x00000000170c3750 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c39ecc 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2042: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a57c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 11. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 2025.10.24 00:15:27.701229 [ 18285 ] {6deb3fa3-a6cc-4ebd-83c7-3cc7440eb9a2} DynamicQueryHandler: Code: 521. DB::ErrnoException: Cannot rename /var/lib/clickhouse/metadata/test.sql.tmp to /var/lib/clickhouse/metadata/test.sql because the second path already exists: , errno: 17, strerror: File exists. (ATOMIC_RENAME_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000170c4008 4. ./build_docker/./src/Common/atomicRename.cpp:92: DB::renameat2(String const&, String const&, int) @ 0x00000000170c3d44 5. ./build_docker/./src/Common/atomicRename.cpp:213: DB::renameNoReplace(String const&, String const&) @ 0x00000000170c3750 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000017c39ecc 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2042: DB::InterpreterCreateQuery::execute() @ 0x0000000017c5a57c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000018220e07 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000018224f79 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a1425ed 11. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000001a146779 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000001a21ec1b 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000001e6b3f83 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000001e6b47f2 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000001e62da03 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x000000001e62bcd0 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001e62a1aa 18. __tsan_thread_start_func @ 0x000000000758df2f 19. ? @ 0x00007f7c69445ac3 20. ? @ 0x00007f7c694d7850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:15:46.274401 [ 2683 ] {} Application: Closed all listening sockets. Waiting for 11 outstanding connections. 2025.10.24 00:15:51.185084 [ 2683 ] {} Application: Closed connections. But 11 remain. Tip: To increase wait time add to config: 60 2025.10.24 00:15:51.185441 [ 2683 ] {} Application: Will shutdown forcefully. 2025.10.24 00:15:53.360168 [ 35208 ] {} Context: Server was built with thread sanitizer. It will work slowly. 2025.10.24 00:15:53.400305 [ 35208 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.10.24 00:15:53.401874 [ 35208 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.10.24 00:15:53.403150 [ 35208 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.10.24 00:15:54.973272 [ 35208 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.10.24 00:15:54.988994 [ 35208 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.10.24 00:15:54.989071 [ 35208 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.10.24 00:15:55.041266 [ 35805 ] {} RaftInstance: Election timeout, initiate leader election 2025.10.24 00:15:56.672403 [ 35952 ] {} system.asynchronous_metric_log (34e0b00e-fe5a-47d8-af0c-3ae1d30a34d1): Removing temporary directory /var/lib/clickhouse/store/34e/34e0b00e-fe5a-47d8-af0c-3ae1d30a34d1/tmp_merge_202510_1_266_87/ 2025.10.24 00:15:56.675854 [ 35935 ] {} system.zookeeper_log (3391eeb9-30c2-4727-900d-ef688a8fcf48): Removing temporary directory /var/lib/clickhouse/store/339/3391eeb9-30c2-4727-900d-ef688a8fcf48/tmp_merge_202510_1_207_42/ 2025.10.24 00:15:59.948039 [ 35208 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.10.24 00:16:00.630925 [ 35208 ] {} loadMetadata: Removing temporary file /var/lib/clickhouse/metadata/test.sql.tmp 2025.10.24 00:16:00.951689 [ 35208 ] {} TablesLoader: Tables test_1.dist_01247 depend on default.number, but seems like that does not exist. Will ignore it and try to load existing tables 2025.10.24 00:16:02.132323 [ 35636 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007ffa90ce6ac3 18. ? @ 0x00007ffa90d78850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:16:02.353432 [ 35217 ] {496f9646-da0a-45f1-acf5-53111f64d6bc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47460) (in query: SELECT count() FROM system.build_options WHERE name = 'CXX_FLAGS' AND position('sanitize=address' IN value)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007ffa90ce6ac3 15. ? @ 0x00007ffa90d78850 2025.10.24 00:16:02.354390 [ 35217 ] {496f9646-da0a-45f1-acf5-53111f64d6bc} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007ffa90ce6ac3 15. ? @ 0x00007ffa90d78850 2025.10.24 00:16:07.699400 [ 35217 ] {19e651b6-8d9c-4122-86b3-ae595e237bca} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:47468) (in query: SELECT count() FROM system.build_options WHERE name = 'CXX_FLAGS' AND position('sanitize=address' IN value)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f5511 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007ffa90ce6ac3 17. ? @ 0x00007ffa90d78850 2025.10.24 00:16:07.700528 [ 35217 ] {19e651b6-8d9c-4122-86b3-ae595e237bca} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000001a2f5511 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001a2f64d3 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 15. __tsan_thread_start_func @ 0x000000000758df2f 16. ? @ 0x00007ffa90ce6ac3 17. ? @ 0x00007ffa90d78850 2025.10.24 00:16:13.031322 [ 35217 ] {b2426525-e7ab-4f74-93d2-fe8a0dfd3a14} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10544.altinitytest (altinity build)) (from [::1]:40294) (in query: SELECT count() FROM system.build_options WHERE name = 'CXX_FLAGS' AND position('sanitize=address' IN value)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007ffa90ce6ac3 15. ? @ 0x00007ffa90d78850 2025.10.24 00:16:13.033539 [ 35217 ] {b2426525-e7ab-4f74-93d2-fe8a0dfd3a14} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001a2f6132 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000001a2f493b 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000001a2f469f 10. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001a308a7b 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 13. __tsan_thread_start_func @ 0x000000000758df2f 14. ? @ 0x00007ffa90ce6ac3 15. ? @ 0x00007ffa90d78850 2025.10.24 00:16:30.188295 [ 35506 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000176a6dc7 9. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000176a755c 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000176b3282 11. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000169b1952 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000169b5c6e 13. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169b6613 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 16. __tsan_thread_start_func @ 0x000000000758df2f 17. ? @ 0x00007ffa90ce6ac3 18. ? @ 0x00007ffa90d78850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:16:30.241193 [ 35832 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {678af7ec-371a-476f-b893-c6848743a362::202510_1_181_37}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007ffa90ce6ac3 31. ? @ 0x00007ffa90d78850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:16:30.250229 [ 35842 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {678af7ec-371a-476f-b893-c6848743a362::202510_1_181_37}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000019ba187d 8. ./src/Common/threadPoolCallbackRunner.h:70: DB::MergeTreeMarksLoader::loadMarksAsync() @ 0x0000000019b9df50 9. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000019b9dc21 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x0000000019bcb176 11. ./contrib/llvm-project/libcxx/include/__tree:1088: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x0000000019ab2a12 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x0000000019aaef0b 13. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x0000000019c01ecf 14. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x0000000019c05e6d 15. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x0000000019c044c2 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000001997389f 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000001996fce5 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000001997732e 19. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000001997e9d7 20. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x0000000019ea1b49 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000199a2169 22. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000199a2d55 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000199a4dc2 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000000fb1c448 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000000fb23e26 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000000fb23d42 27. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x000000000fb18fbe 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fb20f5c 29. __tsan_thread_start_func @ 0x000000000758df2f 30. ? @ 0x00007ffa90ce6ac3 31. ? @ 0x00007ffa90d78850 (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:16:31.226004 [ 35208 ] {} virtual void DB::StorageBuffer::flushAndPrepareForShutdown(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1d86e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageBuffer::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000195f1bd0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::StorageBuffer::flushAndPrepareForShutdown() @ 0x00000000195f19f7 11. ./contrib/llvm-project/libcxx/include/__tree:189: DB::DatabaseWithOwnTablesBase::shutdown() @ 0x0000000017136b19 12. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:184: DB::DatabaseOnDisk::shutdown() @ 0x000000001709b0eb 13. ./contrib/llvm-project/libcxx/include/__tree:189: DB::DatabaseCatalog::shutdownImpl() @ 0x000000001769547f 14. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:869: DB::DatabaseCatalog::shutdown() @ 0x000000001769e52c 15. ./build_docker/./src/Interpreters/Context.cpp:624: DB::ContextSharedPart::shutdown() @ 0x00000000175e4e7d 16. ./build_docker/./src/Interpreters/Context.cpp:4783: DB::Context::shutdown() @ 0x00000000175d2802 17. ./build_docker/./programs/server/Server.cpp:0: BasicScopeGuard> const&)::$_2>::~BasicScopeGuard() @ 0x000000000fc69de6 18. ./build_docker/./programs/server/Server.cpp:0: DB::Server::main(std::vector> const&) @ 0x000000000fc59976 19. ./build_docker/./base/poco/Util/src/Application.cpp:0: Poco::Util::Application::run() @ 0x000000001e6ebd5f 20. ./build_docker/./programs/server/Server.cpp:0: DB::Server::run() @ 0x000000000fc3f326 21. ./build_docker/./base/poco/Util/src/ServerApplication.cpp:0: Poco::Util::ServerApplication::run(int, char**) @ 0x000000001e70a581 22. ./build_docker/./programs/server/Server.cpp:0: mainEntryClickHouseServer(int, char**) @ 0x000000000fc3c156 23. ./build_docker/./programs/main.cpp:0: main @ 0x000000000760c8e9 24. ? @ 0x00007ffa90c7bd90 25. ? @ 0x00007ffa90c7be40 26. _start @ 0x000000000756702e (version 24.8.14.10544.altinitytest (altinity build)) 2025.10.24 00:16:31.342525 [ 35208 ] {} virtual void DB::StorageBuffer::flushAndPrepareForShutdown(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000001e5a7383 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fa0d035 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000761537e 3. ./contrib/llvm-project/libcxx/include/vector:438: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fb21c0c 4. ./build_docker/./src/Common/ThreadPool.cpp:259: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fb24298 5. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fb1e26b 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000000fb1d5ab 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000160e2a43 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000195f1f7c 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageBuffer::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x00000000195f1bd0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:596: DB::StorageBuffer::flushAndPrepareForShutdown() @ 0x00000000195f19f7 11. ./src/Storages/IStorage.h:594: DB::DatabaseWithOwnTablesBase::shutdown() @ 0x0000000017136bea 12. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:184: DB::DatabaseOnDisk::shutdown() @ 0x000000001709b0eb 13. ./contrib/llvm-project/libcxx/include/__tree:189: DB::DatabaseCatalog::shutdownImpl() @ 0x000000001769547f 14. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:869: DB::DatabaseCatalog::shutdown() @ 0x000000001769e52c 15. ./build_docker/./src/Interpreters/Context.cpp:624: DB::ContextSharedPart::shutdown() @ 0x00000000175e4e7d 16. ./build_docker/./src/Interpreters/Context.cpp:4783: DB::Context::shutdown() @ 0x00000000175d2802 17. ./build_docker/./programs/server/Server.cpp:0: BasicScopeGuard> const&)::$_2>::~BasicScopeGuard() @ 0x000000000fc69de6 18. ./build_docker/./programs/server/Server.cpp:0: DB::Server::main(std::vector> const&) @ 0x000000000fc59976 19. ./build_docker/./base/poco/Util/src/Application.cpp:0: Poco::Util::Application::run() @ 0x000000001e6ebd5f 20. ./build_docker/./programs/server/Server.cpp:0: DB::Server::run() @ 0x000000000fc3f326 21. ./build_docker/./base/poco/Util/src/ServerApplication.cpp:0: Poco::Util::ServerApplication::run(int, char**) @ 0x000000001e70a581 22. ./build_docker/./programs/server/Server.cpp:0: mainEntryClickHouseServer(int, char**) @ 0x000000000fc3c156 23. ./build_docker/./programs/main.cpp:0: main @ 0x000000000760c8e9 24. ? @ 0x00007ffa90c7bd90 25. ? @ 0x00007ffa90c7be40 26. _start @ 0x000000000756702e (version 24.8.14.10544.altinitytest (altinity build))